A B C D E F G H I J L M N O P Q R S T V

A

add(String) - Method in class com.path.android.jobqueue.CopyOnWriteGroupSet
 
addJob(Job) - Method in class com.path.android.jobqueue.JobManager
Adds a new Job to the list and returns an ID for it.
addJob(int, BaseJob) - Method in class com.path.android.jobqueue.JobManager
Deprecated. 
addJob(int, long, BaseJob) - Method in class com.path.android.jobqueue.JobManager
Deprecated. 
addJobInBackground(Job) - Method in class com.path.android.jobqueue.JobManager
Non-blocking convenience method to add a job in background thread.
addJobInBackground(Job, AsyncAddCallback) - Method in class com.path.android.jobqueue.JobManager
 
addJobInBackground(int, BaseJob) - Method in class com.path.android.jobqueue.JobManager
Deprecated. 
addJobInBackground(int, long, BaseJob) - Method in class com.path.android.jobqueue.JobManager
Deprecated. 
addJobInBackground(int, long, BaseJob, AsyncAddCallback) - Method in class com.path.android.jobqueue.JobManager
 
AsyncAddCallback - Interface in com.path.android.jobqueue
If you are adding the job via the async adder, you can provide a callback method to receive the ID.

B

BaseJob - Class in com.path.android.jobqueue
Deprecated. 
BaseJob(boolean) - Constructor for class com.path.android.jobqueue.BaseJob
Deprecated.  
BaseJob(String) - Constructor for class com.path.android.jobqueue.BaseJob
Deprecated.  
BaseJob(boolean, String) - Constructor for class com.path.android.jobqueue.BaseJob
Deprecated.  
BaseJob(boolean, boolean) - Constructor for class com.path.android.jobqueue.BaseJob
Deprecated.  
BaseJob(boolean, boolean, String) - Constructor for class com.path.android.jobqueue.BaseJob
Deprecated.  
build() - Method in class com.path.android.jobqueue.config.Configuration.Builder
 

C

CachedJobQueue - Class in com.path.android.jobqueue.cachedQueue
a class that implements JobQueue interface, wraps another JobQueue and caches results to avoid unnecessary queries to wrapped JobQueue.
CachedJobQueue(JobQueue) - Constructor for class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
clear() - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
clear() - Method in class com.path.android.jobqueue.CopyOnWriteGroupSet
 
clear() - Method in class com.path.android.jobqueue.JobManager
 
clear() - Method in interface com.path.android.jobqueue.JobQueue
clear all jobs in the queue.
clear() - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
clear() - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
clear() - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
clear() - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
clear all jobs in the queue.
clear() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.QueryCache
 
clear() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
clear all jobs in the queue.
columnIndex - Variable in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper.Property
 
com.path.android.jobqueue - package com.path.android.jobqueue
 
com.path.android.jobqueue.cachedQueue - package com.path.android.jobqueue.cachedQueue
 
com.path.android.jobqueue.config - package com.path.android.jobqueue.config
 
com.path.android.jobqueue.di - package com.path.android.jobqueue.di
 
com.path.android.jobqueue.executor - package com.path.android.jobqueue.executor
 
com.path.android.jobqueue.log - package com.path.android.jobqueue.log
 
com.path.android.jobqueue.network - package com.path.android.jobqueue.network
 
com.path.android.jobqueue.nonPersistentQueue - package com.path.android.jobqueue.nonPersistentQueue
 
com.path.android.jobqueue.persistentQueue.sqlite - package com.path.android.jobqueue.persistentQueue.sqlite
 
compare(JobHolder, JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.ConsistentTimedComparator
 
compare(JobHolder, JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.TimeAwareComparator
 
Configuration - Class in com.path.android.jobqueue.config
JobManager configuration object
Configuration.Builder - Class in com.path.android.jobqueue.config
 
Configuration.Builder(Context) - Constructor for class com.path.android.jobqueue.config.Configuration.Builder
 
considerAddingConsumer() - Method in class com.path.android.jobqueue.executor.JobConsumerExecutor
creates a new consumer thread if needed.
ConsistentTimedComparator - Class in com.path.android.jobqueue.nonPersistentQueue
A job holder comparator that checks time before checking anything else
ConsistentTimedComparator(Comparator<JobHolder>) - Constructor for class com.path.android.jobqueue.nonPersistentQueue.ConsistentTimedComparator
 
consumerKeepAlive(int) - Method in class com.path.android.jobqueue.config.Configuration.Builder
When JobManager runs out of `ready` jobs, it will keep consumers alive for this duration.
CopyOnWriteGroupSet - Class in com.path.android.jobqueue
a util class that holds running jobs sorted by name and uniq.
CopyOnWriteGroupSet() - Constructor for class com.path.android.jobqueue.CopyOnWriteGroupSet
 
count() - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
count() - Method in class com.path.android.jobqueue.JobManager
returns the # of jobs that are waiting to be executed.
count() - Method in interface com.path.android.jobqueue.JobQueue
Returns the # of jobs that are waiting to be run
count() - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
Returns the # of jobs that are waiting to be run
count() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
Returns the # of jobs that are waiting to be run
countReadyJobs(boolean, Collection<String>) - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
countReadyJobs(boolean, Collection<String>) - Method in interface com.path.android.jobqueue.JobQueue
counts the # of jobs that can run now.
countReadyJobs(long, Collection<String>) - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
countReadyJobs(Collection<String>) - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
countReadyJobs(MergedQueue.SetId, long, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
 
countReadyJobs(MergedQueue.SetId, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
 
countReadyJobs(boolean, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NetworkAwarePriorityQueue
 
countReadyJobs(long, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NetworkAwarePriorityQueue
 
countReadyJobs(Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NetworkAwarePriorityQueue
 
countReadyJobs(long, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
countReadyJobs(Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
countReadyJobs(boolean, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
 
countReadyJobs(long, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.TimeAwarePriorityQueue
 
countReadyJobs(Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.TimeAwarePriorityQueue
 
countReadyJobs(boolean, Collection<String>) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
 
countRemainingReadyJobs() - Method in interface com.path.android.jobqueue.executor.JobConsumerExecutor.Contract
 
CountWithGroupIdsResult - Class in com.path.android.jobqueue.nonPersistentQueue
 
CountWithGroupIdsResult(int, Set<String>) - Constructor for class com.path.android.jobqueue.nonPersistentQueue.CountWithGroupIdsResult
 
create(String, SqlHelper.Property, SqlHelper.Property...) - Static method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
createdNs - Variable in class com.path.android.jobqueue.JobHolder
When job is created, System.nanoTime() is assigned to createdNs value so that we know when job is created in relation to others
createNonPersistent(Context, Long, String) - Method in class com.path.android.jobqueue.JobManager.DefaultQueueFactory
 
createNonPersistent(Context, Long, String) - Method in interface com.path.android.jobqueue.QueueFactory
 
createPersistentQueue(Context, Long, String) - Method in class com.path.android.jobqueue.JobManager.DefaultQueueFactory
 
createPersistentQueue(Context, Long, String) - Method in interface com.path.android.jobqueue.QueueFactory
 
createQueue(MergedQueue.SetId, int, Comparator<JobHolder>) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
called when we want to create the subsequent queues
createQueue(MergedQueue.SetId, int, Comparator<JobHolder>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NetworkAwarePriorityQueue
create a TimeAwarePriorityQueue
createQueue(MergedQueue.SetId, int, Comparator<JobHolder>) - Method in class com.path.android.jobqueue.nonPersistentQueue.TimeAwarePriorityQueue
create a PriorityQueue with given comparator
createSelect(String, Integer, SqlHelper.Order...) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
customLogger(CustomLogger) - Method in class com.path.android.jobqueue.config.Configuration.Builder
you can provide a custom logger to get logs from JobManager.
CustomLogger - Interface in com.path.android.jobqueue.log
You can provide your own logger implementation to JobManager it is very similar to Roboguice's logger

D

d(String, Object...) - Method in interface com.path.android.jobqueue.log.CustomLogger
 
d(String, Object...) - Static method in class com.path.android.jobqueue.log.JqLog
 
DbOpenHelper - Class in com.path.android.jobqueue.persistentQueue.sqlite
Helper class for SqliteJobQueue to handle database connection
DbOpenHelper(Context, String) - Constructor for class com.path.android.jobqueue.persistentQueue.sqlite.DbOpenHelper
 
decideQueue(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
decides which queue should the job holder go if first queue, should return 0 if second queue, should return 1 is only called when an item is inserted.
decideQueue(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.NetworkAwarePriorityQueue
 
decideQueue(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.TimeAwarePriorityQueue
 
DEFAULT_ID - Static variable in class com.path.android.jobqueue.config.Configuration
 
DEFAULT_LOAD_FACTOR_PER_CONSUMER - Static variable in class com.path.android.jobqueue.config.Configuration
 
DEFAULT_RETRY_LIMIT - Static variable in class com.path.android.jobqueue.BaseJob
Deprecated.  
DEFAULT_THREAD_KEEP_ALIVE_SECONDS - Static variable in class com.path.android.jobqueue.config.Configuration
 
delayInMs(long) - Method in class com.path.android.jobqueue.Params
Delays the job in given ms.
delayUntilNs - Variable in class com.path.android.jobqueue.JobHolder
job will be delayed until this nanotime
DependencyInjector - Interface in com.path.android.jobqueue.di
interface that can be provided to JobManager for dependency injection it is called before the job's onAdded method is called.
deserialize(byte[]) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue.JavaSerializer
 
deserialize(byte[]) - Method in interface com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue.JobSerializer
 
doesRequireNetwork() - Method in class com.path.android.jobqueue.Params
 
drop(String) - Static method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 

E

e(Throwable, String, Object...) - Method in interface com.path.android.jobqueue.log.CustomLogger
 
e(String, Object...) - Method in interface com.path.android.jobqueue.log.CustomLogger
 
e(Throwable, String, Object...) - Static method in class com.path.android.jobqueue.log.JqLog
 
e(String, Object...) - Static method in class com.path.android.jobqueue.log.JqLog
 
equals(Object) - Method in class com.path.android.jobqueue.JobHolder
 

F

findById(long) - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
findById(long) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
Returns the JobHolder that has the given id
findById(long) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
findJobById(long) - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
findJobById(long) - Method in interface com.path.android.jobqueue.JobQueue
returns the job with the given id if it exists in the queue
findJobById(long) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
returns the job with the given id if it exists in the queue
findJobById(long) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
returns the job with the given id if it exists in the queue

G

get(boolean, Collection<String>) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.QueryCache
 
getBaseJob() - Method in class com.path.android.jobqueue.JobHolder
 
getConsumerKeepAlive() - Method in class com.path.android.jobqueue.config.Configuration
 
getCount() - Method in class com.path.android.jobqueue.nonPersistentQueue.CountWithGroupIdsResult
 
getCountStatement() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
getCreatedNs() - Method in class com.path.android.jobqueue.JobHolder
 
getCurrentRunCount() - Method in class com.path.android.jobqueue.BaseJob
Deprecated. before each run, JobManager sets this number.
getCustomLogger() - Method in class com.path.android.jobqueue.config.Configuration
 
getDelayInMs() - Method in class com.path.android.jobqueue.Job
used by JobManager to assign proper delay at the time job is added.
getDelayMs() - Method in class com.path.android.jobqueue.Params
 
getDelayUntilNs() - Method in class com.path.android.jobqueue.JobHolder
 
getDeleteStatement() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
getDependencyInjector() - Method in class com.path.android.jobqueue.config.Configuration
 
getGroupId() - Method in class com.path.android.jobqueue.JobHolder
 
getGroupId() - Method in class com.path.android.jobqueue.Params
 
getGroupIds() - Method in class com.path.android.jobqueue.nonPersistentQueue.CountWithGroupIdsResult
 
getId() - Method in class com.path.android.jobqueue.config.Configuration
 
getId() - Method in class com.path.android.jobqueue.JobHolder
 
getInsertOrReplaceStatement() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
getInsertStatement() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
getJobStatus(long, boolean) - Method in class com.path.android.jobqueue.JobManager
Returns the current status of a Job.
getLoadFactor() - Method in class com.path.android.jobqueue.config.Configuration
 
getMaxConsumerCount() - Method in class com.path.android.jobqueue.config.Configuration
 
getMinConsumerCount() - Method in class com.path.android.jobqueue.config.Configuration
 
getNetworkUtil() - Method in class com.path.android.jobqueue.config.Configuration
 
getNextJob(int, TimeUnit) - Method in interface com.path.android.jobqueue.executor.JobConsumerExecutor.Contract
should return the next job which is available to be run.
getNextJobDelayedUntilWithNetworkStatement() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
getNextJobDelayedUntilWithoutNetworkStatement() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
getNextJobDelayUntilNs(boolean) - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
getNextJobDelayUntilNs(boolean) - Method in interface com.path.android.jobqueue.JobQueue
returns when the next job should run (in nanoseconds), should return null if there are no jobs to run.
getNextJobDelayUntilNs(boolean) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
returns when the next job should run (in nanoseconds), should return null if there are no jobs to run.
getNextJobDelayUntilNs(boolean) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
returns when the next job should run (in nanoseconds), should return null if there are no jobs to run.
getOnJobFetchedForRunningStatement() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
getPriority() - Method in class com.path.android.jobqueue.Job
used by JobManager to assign proper priority at the time job is added.
getPriority() - Method in class com.path.android.jobqueue.JobHolder
 
getPriority() - Method in class com.path.android.jobqueue.Params
 
getQueueFactory() - Method in class com.path.android.jobqueue.config.Configuration
 
getRetryLimit() - Method in class com.path.android.jobqueue.BaseJob
Deprecated. By default, jobs will be retried DEFAULT_RETRY_LIMIT times.
getRunCount() - Method in class com.path.android.jobqueue.JobHolder
 
getRunGroupId() - Method in class com.path.android.jobqueue.BaseJob
Deprecated. Some jobs may require being run synchronously.
getRunningSessionId() - Method in class com.path.android.jobqueue.JobHolder
 
getSafe() - Method in class com.path.android.jobqueue.CopyOnWriteGroupSet
 
groupBy(String) - Method in class com.path.android.jobqueue.Params
Sets the group id.
groupId - Variable in class com.path.android.jobqueue.JobHolder
 

H

hashCode() - Method in class com.path.android.jobqueue.JobHolder
 

I

id(String) - Method in class com.path.android.jobqueue.config.Configuration.Builder
provide and ID for this job manager to be used while creating persistent queue.
id - Variable in class com.path.android.jobqueue.JobHolder
 
inject(BaseJob) - Method in interface com.path.android.jobqueue.di.DependencyInjector
 
injector(DependencyInjector) - Method in class com.path.android.jobqueue.config.Configuration.Builder
JobManager is suitable for DependencyInjection.
insert(JobHolder) - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
insert(JobHolder) - Method in interface com.path.android.jobqueue.JobQueue
Inserts the given JobHolder, assigns it a unique id and returns the id back Is called when a job is added
insert(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
Inserts the given JobHolder, assigns it a unique id and returns the id back Is called when a job is added
insert(JobHolder) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
Inserts the given JobHolder, assigns it a unique id and returns the id back Is called when a job is added
insertOrReplace(JobHolder) - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
insertOrReplace(JobHolder) - Method in interface com.path.android.jobqueue.executor.JobConsumerExecutor.Contract
should insert the given JobHolder to related JobQueue.
insertOrReplace(JobHolder) - Method in interface com.path.android.jobqueue.JobQueue
Does the same thing with insert but the only difference is that if job has an ID, it should replace the existing one should also reset running session id to JobManager.NOT_RUNNING_SESSION_ID Is called when a job is re-added (due to exception during run)
insertOrReplace(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
Does the same thing with insert but the only difference is that if job has an ID, it should replace the existing one should also reset running session id to JobManager.NOT_RUNNING_SESSION_ID Is called when a job is re-added (due to exception during run)
insertOrReplace(JobHolder) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
Does the same thing with insert but the only difference is that if job has an ID, it should replace the existing one should also reset running session id to JobManager.NOT_RUNNING_SESSION_ID Is called when a job is re-added (due to exception during run)
isConnected(Context) - Method in interface com.path.android.jobqueue.network.NetworkUtil
 
isConnected(Context) - Method in class com.path.android.jobqueue.network.NetworkUtilImpl
 
isDebugEnabled() - Method in interface com.path.android.jobqueue.log.CustomLogger
JobManager may call this before logging sth that is (relatively) expensive to calculate
isDebugEnabled() - Static method in class com.path.android.jobqueue.log.JqLog
 
isPersistent() - Method in class com.path.android.jobqueue.BaseJob
Deprecated. defines if we should add this job to disk or non-persistent queue
isPersistent() - Method in class com.path.android.jobqueue.Params
 
isRunning() - Method in interface com.path.android.jobqueue.executor.JobConsumerExecutor.Contract
 
isRunning(long, boolean) - Method in class com.path.android.jobqueue.executor.JobConsumerExecutor
returns true if job is currently handled by one of the executor threads

J

Job - Class in com.path.android.jobqueue
Base class for all of your jobs.
Job(Params) - Constructor for class com.path.android.jobqueue.Job
 
jobComparator - Variable in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
 
JobConsumerExecutor - Class in com.path.android.jobqueue.executor
An executor class that takes care of spinning consumer threads and making sure enough is alive.
JobConsumerExecutor(Configuration, JobConsumerExecutor.Contract) - Constructor for class com.path.android.jobqueue.executor.JobConsumerExecutor
 
JobConsumerExecutor.Contract - Interface in com.path.android.jobqueue.executor
contract between the JobManager and JobConsumerExecutor
JobHolder - Class in com.path.android.jobqueue
Container class to address Jobs inside job manager.
JobHolder(Long, int, String, int, BaseJob, long, long, long) - Constructor for class com.path.android.jobqueue.JobHolder
 
JobHolder(int, BaseJob, long) - Constructor for class com.path.android.jobqueue.JobHolder
 
JobHolder(int, BaseJob, long, long) - Constructor for class com.path.android.jobqueue.JobHolder
 
JobManager - Class in com.path.android.jobqueue
a JobManager that supports; -> Persistent / Non Persistent Jobs -> Job Priority -> Running Jobs in Parallel -> Grouping jobs so that they won't run at the same time -> Stats like waiting Job Count
JobManager(Context) - Constructor for class com.path.android.jobqueue.JobManager
Default constructor that will create a JobManager with 1 SqliteJobQueue and 1 NonPersistentPriorityQueue
JobManager(Context, String) - Constructor for class com.path.android.jobqueue.JobManager
Default constructor that will create a JobManager with a default Configuration
JobManager(Context, Configuration) - Constructor for class com.path.android.jobqueue.JobManager
 
JobManager.DefaultQueueFactory - Class in com.path.android.jobqueue
Default implementation of QueueFactory that creates one SqliteJobQueue and one NonPersistentPriorityQueue both are wrapped inside a CachedJobQueue to improve performance
JobManager.DefaultQueueFactory() - Constructor for class com.path.android.jobqueue.JobManager.DefaultQueueFactory
 
JobManager.DefaultQueueFactory(SqliteJobQueue.JobSerializer) - Constructor for class com.path.android.jobqueue.JobManager.DefaultQueueFactory
 
JobQueue - Interface in com.path.android.jobqueue
Interface that any JobQueue should implement These job queues can be given to JobManager.
jobSerializer(SqliteJobQueue.JobSerializer) - Method in class com.path.android.jobqueue.config.Configuration.Builder
convenient configuration to replace job serializer while using SqliteJobQueue queue for persistence.
JobSet - Interface in com.path.android.jobqueue.nonPersistentQueue
An interface for Job Containers It is very similar to SortedSet
JobStatus - Enum in com.path.android.jobqueue
Identifies the current status of a job if it is in the queue
JqLog - Class in com.path.android.jobqueue.log
Wrapper around CustomLogger.
JqLog() - Constructor for class com.path.android.jobqueue.log.JqLog
 

L

loadFactor(int) - Method in class com.path.android.jobqueue.config.Configuration.Builder
calculated by # of jobs (running+waiting) per thread for instance, at a given time, if you have two consumers and 10 jobs in waiting queue (or running right now), load is (10/2) =5 defaults to

M

MAX_CONSUMER_COUNT - Static variable in class com.path.android.jobqueue.config.Configuration
 
maxConsumerCount(int) - Method in class com.path.android.jobqueue.config.Configuration.Builder
# of max consumers to run concurrently.
MergedQueue - Class in com.path.android.jobqueue.nonPersistentQueue
A queue implementation that utilize two queues depending on one or multiple properties of the JobHolder While retrieving items, it uses a different comparison method to handle dynamic comparisons (e.g.
MergedQueue(int, Comparator<JobHolder>, Comparator<JobHolder>) - Constructor for class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
 
MergedQueue.SetId - Enum in com.path.android.jobqueue.nonPersistentQueue
simple enum to identify queues
mergeWith(CountWithGroupIdsResult) - Method in class com.path.android.jobqueue.nonPersistentQueue.CountWithGroupIdsResult
 
MIN_CONSUMER_COUNT - Static variable in class com.path.android.jobqueue.config.Configuration
 
minConsumerCount(int) - Method in class com.path.android.jobqueue.config.Configuration.Builder
you can specify to keep minConsumers alive even if there are no ready jobs.

N

NetworkAwarePriorityQueue - Class in com.path.android.jobqueue.nonPersistentQueue
A MergedQueue class that can separate jobs based on their network requirement
NetworkAwarePriorityQueue(int, Comparator<JobHolder>) - Constructor for class com.path.android.jobqueue.nonPersistentQueue.NetworkAwarePriorityQueue
create a network aware priority queue with given initial capacity * 2 and comparator
NetworkEventProvider - Interface in com.path.android.jobqueue.network
An interface that NetworkUtil can implement if it supports a callback method when network state is changed This is not mandatory but highly suggested so that JobManager can avoid busy loops when there is a job waiting for network and there is no network available
NetworkEventProvider.Listener - Interface in com.path.android.jobqueue.network
 
networkUtil(NetworkUtil) - Method in class com.path.android.jobqueue.config.Configuration.Builder
By default, Job Manager comes with a simple NetworkUtilImpl that queries ConnectivityManager to check if network connection exists.
NetworkUtil - Interface in com.path.android.jobqueue.network
Interface which you can implement if you want to provide a custom Network callback.
NetworkUtilImpl - Class in com.path.android.jobqueue.network
default implementation for network Utility to observe network events
NetworkUtilImpl(Context) - Constructor for class com.path.android.jobqueue.network.NetworkUtilImpl
 
nextJobAndIncRunCount(boolean, Collection<String>) - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
nextJobAndIncRunCount(boolean, Collection<String>) - Method in interface com.path.android.jobqueue.JobQueue
Returns the next available job in the data set It should also assign the sessionId as the RunningSessionId and persist that data if necessary.
nextJobAndIncRunCount(boolean, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
Returns the next available job in the data set It should also assign the sessionId as the RunningSessionId and persist that data if necessary.
nextJobAndIncRunCount(boolean, Collection<String>) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
Returns the next available job in the data set It should also assign the sessionId as the RunningSessionId and persist that data if necessary.
NonPersistentJobSet - Class in com.path.android.jobqueue.nonPersistentQueue
This is the default implementation of JobSet.
NonPersistentJobSet(Comparator<JobHolder>) - Constructor for class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
NonPersistentPriorityQueue - Class in com.path.android.jobqueue.nonPersistentQueue
 
NonPersistentPriorityQueue(long, String) - Constructor for class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
 
NOT_DELAYED_JOB_DELAY - Static variable in class com.path.android.jobqueue.JobManager
 
NOT_RUNNING_SESSION_ID - Static variable in class com.path.android.jobqueue.JobManager
 
NS_PER_MS - Static variable in class com.path.android.jobqueue.JobManager
 

O

offer(JobHolder) - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
offer(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
offer(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
onAdded(long) - Method in interface com.path.android.jobqueue.AsyncAddCallback
 
onAdded() - Method in class com.path.android.jobqueue.BaseJob
Deprecated. called when the job is added to disk and committed.
onCancel() - Method in class com.path.android.jobqueue.BaseJob
Deprecated. called when a job is cancelled.
onCreate(SQLiteDatabase) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.DbOpenHelper
 
onNetworkChange(boolean) - Method in class com.path.android.jobqueue.JobManager
if NetworkUtil implements NetworkEventProvider, this method is called when network is recovered
onNetworkChange(boolean) - Method in interface com.path.android.jobqueue.network.NetworkEventProvider.Listener
 
onRun() - Method in class com.path.android.jobqueue.BaseJob
Deprecated. The actual method that should to the work It should finish w/o any exception.
onUpgrade(SQLiteDatabase, int, int) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.DbOpenHelper
 

P

Params - Class in com.path.android.jobqueue
BaseJob builder object to have a more readable design.
Params(int) - Constructor for class com.path.android.jobqueue.Params
 
peek(Collection<String>) - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
peek(Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
peek(boolean, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NetworkAwarePriorityQueue
Queue.peek() implementation with network requirement filter
peek(Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
peekFromQueue(MergedQueue.SetId, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
used to peek from one of the queues
persist() - Method in class com.path.android.jobqueue.Params
Marks the job as persistent.
poll(Collection<String>) - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
poll(Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
poll(boolean, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NetworkAwarePriorityQueue
Queue.poll() implementation with network requirement filter
poll(Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
pollFromQueue(MergedQueue.SetId, Collection<String>) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
used to poll from one of the queues
priority - Variable in class com.path.android.jobqueue.JobHolder
 

Q

QueryCache - Class in com.path.android.jobqueue.persistentQueue.sqlite
a class to cache ready jobs queries so that we can avoid unnecessary memory allocations for them
QueryCache() - Constructor for class com.path.android.jobqueue.persistentQueue.sqlite.QueryCache
 
queueFactory(QueueFactory) - Method in class com.path.android.jobqueue.config.Configuration.Builder
JobManager needs one persistent and one non-persistent JobQueue to function.
QueueFactory - Interface in com.path.android.jobqueue
Interface to supply custom JobQueues for JobManager

R

remove(JobHolder) - Method in class com.path.android.jobqueue.cachedQueue.CachedJobQueue
 
remove(String) - Method in class com.path.android.jobqueue.CopyOnWriteGroupSet
 
remove(JobHolder) - Method in interface com.path.android.jobqueue.JobQueue
Removes the job from the data store.
remove(JobHolder) - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
remove(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
remove(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
remove(JobHolder) - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentPriorityQueue
Removes the job from the data store.
remove(JobHolder) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
Removes the job from the data store.
removeJob(JobHolder) - Method in interface com.path.android.jobqueue.executor.JobConsumerExecutor.Contract
should remove the job from the related JobQueue
requireNetwork() - Method in class com.path.android.jobqueue.Params
Sets the Job as requiring network
requiresNetwork() - Method in class com.path.android.jobqueue.BaseJob
Deprecated. if job is set to require network, it will not be called unless NetworkUtil reports that there is a network connection
requiresNetwork - Variable in class com.path.android.jobqueue.JobHolder
 
requiresNetwork() - Method in class com.path.android.jobqueue.JobHolder
 
resetDelayTimesTo(long) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
runCount - Variable in class com.path.android.jobqueue.JobHolder
 
runningSessionId - Variable in class com.path.android.jobqueue.JobHolder
 

S

safeRun(int) - Method in class com.path.android.jobqueue.BaseJob
Deprecated. Runs the job and catches any exception
safeRun(int) - Method in class com.path.android.jobqueue.JobHolder
runs the job w/o throwing any exceptions
serialize(Object) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue.JavaSerializer
 
serialize(Object) - Method in interface com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue.JobSerializer
 
set(String, boolean, Collection<String>) - Method in class com.path.android.jobqueue.persistentQueue.sqlite.QueryCache
 
setBaseJob(BaseJob) - Method in class com.path.android.jobqueue.JobHolder
 
setCreatedNs(long) - Method in class com.path.android.jobqueue.JobHolder
 
setCustomLogger(CustomLogger) - Static method in class com.path.android.jobqueue.log.JqLog
 
setDelayMs(long) - Method in class com.path.android.jobqueue.Params
convenience method to set delay
setGroupId(String) - Method in class com.path.android.jobqueue.Params
convenience method to set group id.
setId(Long) - Method in class com.path.android.jobqueue.JobHolder
 
setListener(NetworkEventProvider.Listener) - Method in interface com.path.android.jobqueue.network.NetworkEventProvider
 
setListener(NetworkEventProvider.Listener) - Method in class com.path.android.jobqueue.network.NetworkUtilImpl
 
setPersistent(boolean) - Method in class com.path.android.jobqueue.Params
convenience method to set whether JobManager should persist this job or not.
setPriority(int) - Method in class com.path.android.jobqueue.JobHolder
 
setRequiresNetwork(boolean) - Method in class com.path.android.jobqueue.Params
convenience method to set network requirement
setRunCount(int) - Method in class com.path.android.jobqueue.JobHolder
 
setRunningSessionId(long) - Method in class com.path.android.jobqueue.JobHolder
 
shouldReRunOnThrowable(Throwable) - Method in class com.path.android.jobqueue.BaseJob
Deprecated. if onRun method throws an exception, this method is called.
size() - Method in interface com.path.android.jobqueue.nonPersistentQueue.JobSet
 
size() - Method in class com.path.android.jobqueue.nonPersistentQueue.MergedQueue
size() - Method in class com.path.android.jobqueue.nonPersistentQueue.NonPersistentJobSet
 
SqlHelper - Class in com.path.android.jobqueue.persistentQueue.sqlite
Helper class for SqliteJobQueue to generate sql queries and statements.
SqlHelper(SQLiteDatabase, String, String, int, long) - Constructor for class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
SqlHelper.Order - Class in com.path.android.jobqueue.persistentQueue.sqlite
 
SqlHelper.Order(SqlHelper.Property, SqlHelper.Order.Type) - Constructor for class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper.Order
 
SqlHelper.Order.Type - Enum in com.path.android.jobqueue.persistentQueue.sqlite
 
SqlHelper.Property - Class in com.path.android.jobqueue.persistentQueue.sqlite
 
SqlHelper.Property(String, String, int) - Constructor for class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper.Property
 
SqliteJobQueue - Class in com.path.android.jobqueue.persistentQueue.sqlite
Persistent Job Queue that keeps its data in an sqlite database.
SqliteJobQueue(Context, long, String, SqliteJobQueue.JobSerializer) - Constructor for class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue
 
SqliteJobQueue.JavaSerializer - Class in com.path.android.jobqueue.persistentQueue.sqlite
 
SqliteJobQueue.JavaSerializer() - Constructor for class com.path.android.jobqueue.persistentQueue.sqlite.SqliteJobQueue.JavaSerializer
 
SqliteJobQueue.JobSerializer - Interface in com.path.android.jobqueue.persistentQueue.sqlite
 
start() - Method in class com.path.android.jobqueue.JobManager
restarts the JobManager.
stop() - Method in class com.path.android.jobqueue.JobManager
Stops consuming jobs.

T

TimeAwareComparator - Class in com.path.android.jobqueue.nonPersistentQueue
A real-time comparator class that checks current time to decide of both jobs are valid or not.
TimeAwareComparator(Comparator<JobHolder>) - Constructor for class com.path.android.jobqueue.nonPersistentQueue.TimeAwareComparator
 
TimeAwarePriorityQueue - Class in com.path.android.jobqueue.nonPersistentQueue
This is a MergedQueue class that can handle queue updates based on time.
TimeAwarePriorityQueue(int, Comparator<JobHolder>) - Constructor for class com.path.android.jobqueue.nonPersistentQueue.TimeAwarePriorityQueue
When retrieving jobs, considers current system nanotime to check if jobs are valid.
truncate() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 

V

vacuum() - Method in class com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper
 
valueOf(String) - Static method in enum com.path.android.jobqueue.JobStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.path.android.jobqueue.nonPersistentQueue.MergedQueue.SetId
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper.Order.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.path.android.jobqueue.JobStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.path.android.jobqueue.nonPersistentQueue.MergedQueue.SetId
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.path.android.jobqueue.persistentQueue.sqlite.SqlHelper.Order.Type
Returns an array containing the constants of this enum type, in the order they are declared.

A B C D E F G H I J L M N O P Q R S T V