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

A

AbstractJobQueue - Class in org.apache.sling.event.impl.jobs.queues
The job blocking queue extends the blocking queue by some functionality for the job event handling.
AbstractJobQueue(String, InternalQueueConfiguration, QueueServices, Set<String>) - Constructor for class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Create a new queue
AbstractJobStatistics - Class in org.apache.sling.event.impl.jobs.jmx
 
AbstractJobStatistics() - Constructor for class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
acknowledgeJob(Event) - Static method in class org.apache.sling.event.EventUtil
acknowledgeJob(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new JobConsumer interface instead.
activate() - Method in class org.apache.sling.event.impl.EnvironmentComponent
Activate this component.
activate(Map<String, Object>) - Method in class org.apache.sling.event.impl.EventingThreadPool
Activate this component.
activate(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
Create a new queue configuration
activate(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Activate this component.
activate(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.config.MainQueueConfiguration
Activate this component.
activate() - Method in class org.apache.sling.event.impl.jobs.deprecated.EventAdminBridge
Activate this component and start background thread
activate(BundleContext) - Method in class org.apache.sling.event.impl.jobs.jmx.QueuesMBeanImpl
 
activate(BundleContext, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
 
activate(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Activate this component.
activate(BundleContext) - Method in class org.apache.sling.event.impl.jobs.notifications.NewJobSender
Activate this component.
activate(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.queues.QueueManager
Activate this component.
activate(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventConfiguration
Activate this component.
activate() - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventReceiver
Activate this component.
activate() - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
Activate this component.
add() - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl
 
add(List<String>) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl
 
add() - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
add(List<String>) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
add(StatisticsImpl) - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Add another statistics information.
add() - Method in interface org.apache.sling.event.jobs.JobBuilder
Add the job.
add(List<String>) - Method in interface org.apache.sling.event.jobs.JobBuilder
Add the job.
add() - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Finally add the job to the schedule
add(List<String>) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Finally add the job to the schedule
addActivated(long) - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
Add a started job.
addActive(long) - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Add a job from the queue to status active
addCancelled() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
Add a cancelled job.
addFailed() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
Add a failed job.
addFinished(long) - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
Add a finished job.
addJob(String, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
addJob(String, String, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
addJob(String, String, Map<String, Object>, List<String>) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Internal method to add a job
addJob(String, Map<String, Object>) - Method in interface org.apache.sling.event.jobs.JobManager
Add a new job If the topic is null or illegal, no job is created and null is returned.
addJob(String, String, Map<String, Object>) - Method in interface org.apache.sling.event.jobs.JobManager
Deprecated. 
addJobToRetryList(Job) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
addListener(ConfigurationChangeListener) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Add a topology aware listener
addListener(ConfigurationChangeListener) - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Add a config listener.
addScheduledJob(String, String, Map<String, Object>, String, boolean, List<ScheduleInfoImpl>, List<String>) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
addToRetryList() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
AllJobStatisticsMBean - Class in org.apache.sling.event.impl.jobs.jmx
 
AllJobStatisticsMBean() - Constructor for class org.apache.sling.event.impl.jobs.jmx.AllJobStatisticsMBean
 
APPLICATION_ID - Static variable in class org.apache.sling.event.impl.support.Environment
Global application id.
asyncProcessingFinished(JobExecutionResult) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Report an async result.
at(Date) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
AT(Date) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
at(Date) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job for a specific date.

B

BatchResourceRemover - Class in org.apache.sling.event.impl.support
This class can be used for batch removal of resources
BatchResourceRemover() - Constructor for class org.apache.sling.event.impl.support.BatchResourceRemover
 
BatchResourceRemover(int) - Constructor for class org.apache.sling.event.impl.support.BatchResourceRemover
 
bindConfig(InternalQueueConfiguration) - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Add a new queue configuration.
bindJobConsumer(ServiceReference) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Bind a new consumer
bindJobExecutor(ServiceReference) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Bind a new executor
bindThreadPool(EventingThreadPool) - Method in class org.apache.sling.event.impl.EnvironmentComponent
 
buildMatchers(String[]) - Static method in class org.apache.sling.event.impl.support.TopicMatcherHelper
Create matchers based on the topic parameters.
BUNDLE_EVENT_STARTED - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
BUNDLE_EVENT_UPDATED - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 

C

canBeClosed() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Check whether this queue can be closed
canBeClosed() - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
cancel() - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer.AsyncHandler
 
cancelJob(String, String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
cancelJob(String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
cancelJob(String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
cancelJob(String, String) - Method in interface org.apache.sling.event.JobStatusProvider
CANCELLED - Static variable in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
Constant object for the cancelled case.
cancelled() - Method in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
 
cancelled() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
The job processing failed permanently.
cancelled() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
If this returns true the job processing failed permanently.
cancelledJob() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Add a cancelled job.
cancelTimedEvent(String) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
cancelTimedEvent(String) - Method in interface org.apache.sling.event.TimedEventStatusProvider
Deprecated.
Cancel this timed event.
check(List<String>) - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
checkForUnprocessedJobs() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Periodically check for started jobs without an acknowledge.
checkJob(Object, Map<String, Object>) - Static method in class org.apache.sling.event.impl.jobs.Utility
Check the job.
checkJobTopic(Object) - Static method in class org.apache.sling.event.impl.jobs.Utility
Check the job topic.
CheckTopologyTask - Class in org.apache.sling.event.impl.jobs.tasks
The check topology task checks for changes in the topology and queue configuration and reassigns jobs.
CheckTopologyTask(JobManagerConfiguration) - Constructor for class org.apache.sling.event.impl.jobs.tasks.CheckTopologyTask
Constructor
CleanUpTask - Class in org.apache.sling.event.impl.jobs.tasks
Maintenance task...
CleanUpTask(JobManagerConfiguration) - Constructor for class org.apache.sling.event.impl.jobs.tasks.CleanUpTask
Constructor
clear() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
clear() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
clear() - Method in interface org.apache.sling.event.jobs.Queue
Deprecated.
This method does nothing anymore
clearJobRetryList() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
clearQueued() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Clear all queued
cloneValueMap(ValueMap) - Static method in class org.apache.sling.event.impl.support.ResourceHelper
 
close() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated. 
close() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Close this queue.
close() - Method in interface org.apache.sling.event.JobsIterator
Deprecated.
Releases this iterators resources immediately instead of waiting for this to happen when it is automatically closed.
compare(InstanceDescription, InstanceDescription) - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities.InstanceDescriptionComparator
 
compareTo(InternalQueueConfiguration) - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
compareTo(JobImpl) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
configuration - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Configuration.
configuration - Variable in class org.apache.sling.event.impl.jobs.queues.QueueServices
 
configurationChanged(boolean) - Method in interface org.apache.sling.event.impl.jobs.config.ConfigurationChangeListener
Notify about a configuration change.
configurationChanged(boolean) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
This method is invoked by the queue configuration manager whenever the queue configuration changes.
configurationChanged(boolean) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
configurationChanged(boolean) - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
 
configurationChanged(boolean) - Method in class org.apache.sling.event.impl.jobs.queues.QueueManager
This method is called whenever the topology or queue configurations change.
ConfigurationChangeListener - Interface in org.apache.sling.event.impl.jobs.config
Listener interface to get topology / queue changes.
ConfigurationConstants - Class in org.apache.sling.event.impl.jobs.config
Constants for the queue configuration.
ConfigurationConstants() - Constructor for class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
containsKey(Object) - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
containsValue(Object) - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
CONTEXT_PROPERTY_NAME - Static variable in interface org.apache.sling.event.impl.jobs.deprecated.JobStatusNotifier
 
copyFrom(StatisticsImpl) - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Create a new statistics object with exactly the same values.
createDistributableEvent(String, Dictionary<String, Object>) - Static method in class org.apache.sling.event.EventUtil
Deprecated.
Event senders should rather just directly include the property EventUtil.PROPERTY_DISTRIBUTE with an empty string value.
createJob(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
createJob(String) - Method in interface org.apache.sling.event.jobs.JobManager
Fluent API to create, start and schedule new jobs
createJobBuilder(ScheduledJobInfoImpl) - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
Create a schedule builder for a currently scheduled job
createResourceResolver() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Create a new resource resolver for reading and writing the resource tree.
cron(String) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
CRON(String) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
cron(String) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job for according to the cron expression.

D

daily(int, int) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
DAILY(int, int) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
daily(int, int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job daily at the given time.
deactivate() - Method in class org.apache.sling.event.impl.EnvironmentComponent
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.EventingThreadPool
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Deactivate
deactivate() - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Deactivate this object.
deactivate() - Method in class org.apache.sling.event.impl.jobs.deprecated.EventAdminBridge
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.jmx.QueuesMBeanImpl
 
deactivate() - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
 
deactivate() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.notifications.NewJobSender
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.queues.QueueManager
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventReceiver
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
Deactivate this component.
debug(String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(Marker, String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(Marker, String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(Marker, String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(Marker, String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
debug(Marker, String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
decQueued() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Job not processed by us
DEFAULT_BACKGROUND_LOAD_DELAY - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Default background load delay.
DEFAULT_BACKGROUND_LOAD_SEARCH - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Default value for background loading.
DEFAULT_DISABLE_DISTRIBUTION - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Default for disabling the distribution.
DEFAULT_KEEP_JOBS - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
DEFAULT_MAX_PARALLEL - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
DEFAULT_PREFER_RUN_ON_CREATION_INSTANCE - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
DEFAULT_PRIORITY - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
DEFAULT_REPOSITORY_PATH - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Default resource path for jobs.
DEFAULT_RETRIES - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
DEFAULT_RETRY_DELAY - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
DEFAULT_SCHEDULED_JOBS_PATH - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Default resource path for scheduled jobs.
DEFAULT_THREAD_POOL_SIZE - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
DEFAULT_TYPE - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
delete(Resource) - Method in class org.apache.sling.event.impl.support.BatchResourceRemover
 
deserialize(ScheduleInfo.ScheduleType, String) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
deserialize(String) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
detectTarget(String, Map<String, Object>, QueueConfigurationManager.QueueInfo) - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Detect the target instance.
disableDistribution() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.sling.event.impl.jobs.console.WebConsolePlugin
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.sling.event.impl.jobs.console.WebConsolePlugin
 

E

elements() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
EmptyStatistics - Class in org.apache.sling.event.impl.jobs.jmx
Dummy stats that just returns 0 for all info, used where the queue doesnt implement the Statistics interface.
EmptyStatistics() - Constructor for class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
entrySet() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
Environment - Class in org.apache.sling.event.impl.support
This class provides "global settings" to all services, like the application id and the thread pool.
Environment() - Constructor for class org.apache.sling.event.impl.support.Environment
 
EnvironmentComponent - Class in org.apache.sling.event.impl
Environment component.
EnvironmentComponent() - Constructor for class org.apache.sling.event.impl.EnvironmentComponent
 
equals(Object) - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
equals(Object) - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager.QueueInfo
 
equals(Object) - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
equals(Object) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
error(String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(Marker, String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(Marker, String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(Marker, String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(Marker, String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
error(Marker, String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
eventAdmin - Variable in class org.apache.sling.event.impl.jobs.queues.QueueServices
 
EventAdminBridge - Class in org.apache.sling.event.impl.jobs.deprecated
Event admin bridge for compatibility.
EventAdminBridge() - Constructor for class org.apache.sling.event.impl.jobs.deprecated.EventAdminBridge
 
EventingThreadPool - Class in org.apache.sling.event.impl
The configurable eventing thread pool.
EventingThreadPool() - Constructor for class org.apache.sling.event.impl.EventingThreadPool
 
EventingThreadPool(ThreadPoolManager, int) - Constructor for class org.apache.sling.event.impl.EventingThreadPool
 
EventPropertiesMap - Class in org.apache.sling.event
Deprecated.
EventAdmin supports creating events with maps now as well.
EventPropertiesMap(Event) - Constructor for class org.apache.sling.event.EventPropertiesMap
Deprecated.
Construct a new map out of an event object.
EventPropertiesMap(Map<String, Object>) - Constructor for class org.apache.sling.event.EventPropertiesMap
Deprecated.
Construct a new map out of another map.
EventPropertiesMap() - Constructor for class org.apache.sling.event.EventPropertiesMap
Deprecated.
Construct a new map.
EventUtil - Class in org.apache.sling.event
Deprecated. 
EventUtil() - Constructor for class org.apache.sling.event.EventUtil
Deprecated.
 
EventUtil.JobPriority - Enum in org.apache.sling.event
Deprecated.
Use JobUtil.JobPriority
ExactTopicMatcher - Class in org.apache.sling.event.impl.support
The topic must match exactly.
ExactTopicMatcher(String) - Constructor for class org.apache.sling.event.impl.support.ExactTopicMatcher
 
execute(Runnable) - Method in class org.apache.sling.event.impl.EventingThreadPool
 
execute(JobContext) - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
 
execute(JobContext) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
executeJob(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Execute a job

F

FAILED - Static variable in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
Constant object for the failed case.
failed() - Method in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
 
failed() - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer.AsyncHandler
 
failed() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
The job processing failed and might be retried.
failed(long) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
The job processing failed and might be retried.
failed() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
If this returns true the job processing failed but might be retried..
failedJob() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Add a failed job.
filterName(String) - Static method in class org.apache.sling.event.impl.support.ResourceHelper
Filter the node name for not allowed characters and replace them.
filterQueueName(String) - Static method in class org.apache.sling.event.impl.support.ResourceHelper
Filter the queue name for not allowed characters and replace them - with the exception of the main queue, which will not be filtered
findJob(String, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
findJob(String, Map<String, Object>) - Method in interface org.apache.sling.event.jobs.JobManager
findJobs(JobManager.QueryType, String, long, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
findJobs(JobManager.QueryType, String, long, Map<String, Object>...) - Method in interface org.apache.sling.event.jobs.JobManager
Return all jobs of a given type.
FindUnfinishedJobsTask - Class in org.apache.sling.event.impl.jobs.tasks
This task is executed when the job handling starts.
FindUnfinishedJobsTask() - Constructor for class org.apache.sling.event.impl.jobs.tasks.FindUnfinishedJobsTask
 
finished(Job.JobState, boolean, long) - Method in class org.apache.sling.event.impl.jobs.JobHandler
Finish a job
finishedJob(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated.
finishedJob(Event, boolean) - Method in interface org.apache.sling.event.impl.jobs.deprecated.JobStatusNotifier
Notify that the job is finished.
finishedJob(Event, boolean) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
finishedJob(long) - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Add a finished job
finishedJob(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new JobConsumer interface instead.
forceRemoveJob(String, String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
forceRemoveJob(String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
forceRemoveJob(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
forceRemoveJob(String) - Method in interface org.apache.sling.event.jobs.JobManager
forceRemoveJob(String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
Cancel this job.
forceRemoveJob(String, String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
Cancel this job.
fromConfiguration(Map<String, Object>) - Static method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
Create a new configuration from a config

G

get(Object) - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
getAllInstancesMap(TopologyView) - Static method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
 
getAllJobs(String, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
getAllJobs(String, Map<String, Object>...) - Method in interface org.apache.sling.event.JobStatusProvider
getApplicationId(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated. 
getApplicationIds() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
Deprecated.
getApplicationIds() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Deprecated.
This information is not used anymore
getAssginedJobsPath() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get the resource path for all assigned jobs.
getAt() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getAt() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
Return the scheduled execution date for a schedule of type date.
getAverageProcessingTime() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getAverageProcessingTime() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getAverageProcessingTime() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getAverageProcessingTime() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getAverageProcessingTime() - Method in interface org.apache.sling.event.jobs.Statistics
The average processing time of a job - this only counts finished jobs.
getAverageProcessingTime() - Method in interface org.apache.sling.event.jobs.TopicStatistics
The average processing time of a job - this only counts finished jobs.
getAverageWaitingTime() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getAverageWaitingTime() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getAverageWaitingTime() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getAverageWaitingTime() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getAverageWaitingTime() - Method in interface org.apache.sling.event.jobs.Statistics
The average waiting time of a job in the queue.
getAverageWaitingTime() - Method in interface org.apache.sling.event.jobs.TopicStatistics
The average waiting time of a job in the queue.
getBackgroundLoadDelay() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
getConfiguration() - Method in class org.apache.sling.event.impl.EventingThreadPool
 
getConfiguration() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Return the queue configuration
getConfiguration() - Method in interface org.apache.sling.event.jobs.Queue
Get the corresponding configuration.
getConfigurations() - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Return all configurations.
getCreated() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getCreated() - Method in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains a calendar object specifying the date and time when this job has been created.
getCreatedInstance() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getCreatedInstance() - Method in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains the Sling instance ID of the instance where this job has been created.
getCronExpression() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
If the job is scheduled daily or weekly, return the cron expression
getCurrentJobs(String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
getCurrentJobs(String, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
getCurrentJobs(String) - Method in interface org.apache.sling.event.JobStatusProvider
getCurrentJobs(String, Map<String, Object>...) - Method in interface org.apache.sling.event.JobStatusProvider
getDayOfMonth() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getDayOfMonth() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
If the job is scheduled monthly, returns the day of the month
getDayOfWeek() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getDayOfWeek() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
If the job is scheduled weekly, returns the day of the week
getExecutor(String) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Get the executor for the topic.
getExpression() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getExpression() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
If the schedule is a cron expression, return the expression.
getFinishedDate() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getFinishedDate() - Method in interface org.apache.sling.event.jobs.Job
If the job is cancelled or succeeded, this method will return the finish date.
getFinishedProgressStep() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getFinishedProgressStep() - Method in interface org.apache.sling.event.jobs.Job
If the job is in processing, return the optional information about the finished steps.
getGlobalStatistics() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsManager
Get the global statistics.
getHourOfDay() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getHourOfDay() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
Return the hour of the day for daily and weekly scheduled jobs
getId() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getId() - Method in interface org.apache.sling.event.jobs.Job
Unique job ID.
getInstanceCapabilities() - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Get the instance capabilities.
getJob() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
getJob(String, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getJob(String, Map<String, Object>) - Method in interface org.apache.sling.event.jobs.JobManager
Find a job - either scheduled or active.
getJobById(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getJobById(String) - Method in interface org.apache.sling.event.jobs.JobManager
Return a job based on the unique id.
getJobByName(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getJobByName(String) - Method in interface org.apache.sling.event.jobs.JobManager
Deprecated. 
getJobCreated(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
getJobFromRetryList(String) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
getJobPriority() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getJobPriority() - Method in interface org.apache.sling.event.jobs.Job
Deprecated. 
getJobProperties() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
getJobProperties() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Return the optional job topics.
getJobState() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getJobState() - Method in interface org.apache.sling.event.jobs.Job
Get the job state
getJobStatusNotifier() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusNotifier.NotifierContext
 
getJobTopic() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
getJobTopic() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Return the job topic.
getLastActivatedJobDate() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getLastActivatedJobDate() - Method in interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
getLastActivatedJobTime() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getLastActivatedJobTime() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getLastActivatedJobTime() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getLastActivatedJobTime() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getLastActivatedJobTime() - Method in interface org.apache.sling.event.jobs.Statistics
The time a job has been started last.
getLastActivatedJobTime() - Method in interface org.apache.sling.event.jobs.TopicStatistics
The time a job has been started last.
getLastFinishedJobDate() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getLastFinishedJobDate() - Method in interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
getLastFinishedJobTime() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getLastFinishedJobTime() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getLastFinishedJobTime() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getLastFinishedJobTime() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getLastFinishedJobTime() - Method in interface org.apache.sling.event.jobs.Statistics
The time a job has been finished/failed/cancelled last.
getLastFinishedJobTime() - Method in interface org.apache.sling.event.jobs.TopicStatistics
The time a job has been finished/failed/cancelled last.
getLocalJobsPath() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get the resource path for all jobs assigned to the current instance
getLocksPath() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get the resource path for all locks
getMainConfiguration() - Method in class org.apache.sling.event.impl.jobs.config.MainQueueConfiguration
Return the main queue configuration object.
getMainLogger() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get main logger.
getMainQueueConfiguration() - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Get the configuration for the main queue.
getMaxParallel() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getMaxParallel() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the max number of parallel processes.
getMaxRetries() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getMaxRetries() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the max number of retries, -1 for endless retry!
getMessage() - Method in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
 
getMessage() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
Return the optional message.
getMinuteOfHour() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getMinuteOfHour() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
Return the minute of the hour for daily, weekly and hourly scheduled jobs.
getMonthOfYear() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getMonthOfYear() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
If the job is scheduled yearly, returns the month of the year
getName() - Method in class org.apache.sling.event.impl.EventingThreadPool
 
getName() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
Return the name of the queue.
getName() - Method in class org.apache.sling.event.impl.jobs.jmx.AllJobStatisticsMBean
 
getName() - Method in class org.apache.sling.event.impl.jobs.jmx.QueueMBeanImpl
 
getName() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getName() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Get the name of the job queue.
getName() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
Get the schedule name
getName() - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
getName() - Method in interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
getName() - Method in interface org.apache.sling.event.jobs.Job
Deprecated. 
getName() - Method in interface org.apache.sling.event.jobs.Queue
Get the queue name.
getNextJob() - Method in class org.apache.sling.event.impl.jobs.queues.QueueJobCache
Get the next job.
getNextScheduledExecution() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
getNextScheduledExecution() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getNextScheduledExecution() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Return the next scheduled execution date.
getNumberOfActiveJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getNumberOfActiveJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getNumberOfActiveJobs() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getNumberOfActiveJobs() - Method in interface org.apache.sling.event.jobs.Statistics
Number of jobs currently in processing.
getNumberOfCancelledJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getNumberOfCancelledJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getNumberOfCancelledJobs() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getNumberOfCancelledJobs() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getNumberOfCancelledJobs() - Method in interface org.apache.sling.event.jobs.Statistics
Number of permanently failing or cancelled jobs.
getNumberOfCancelledJobs() - Method in interface org.apache.sling.event.jobs.TopicStatistics
Number of permanently failing or cancelled jobs.
getNumberOfFailedJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getNumberOfFailedJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getNumberOfFailedJobs() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getNumberOfFailedJobs() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getNumberOfFailedJobs() - Method in interface org.apache.sling.event.jobs.Statistics
Number of failing jobs.
getNumberOfFailedJobs() - Method in interface org.apache.sling.event.jobs.TopicStatistics
Number of failing jobs.
getNumberOfFinishedJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getNumberOfFinishedJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getNumberOfFinishedJobs() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getNumberOfFinishedJobs() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getNumberOfFinishedJobs() - Method in interface org.apache.sling.event.jobs.Statistics
Number of successfully finished jobs.
getNumberOfFinishedJobs() - Method in interface org.apache.sling.event.jobs.TopicStatistics
Number of successfully finished jobs.
getNumberOfJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getNumberOfJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getNumberOfJobs() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getNumberOfJobs() - Method in interface org.apache.sling.event.jobs.Statistics
getNumberOfProcessedJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getNumberOfProcessedJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getNumberOfProcessedJobs() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getNumberOfProcessedJobs() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getNumberOfProcessedJobs() - Method in interface org.apache.sling.event.jobs.Statistics
Number of already processed jobs.
getNumberOfProcessedJobs() - Method in interface org.apache.sling.event.jobs.TopicStatistics
Number of already processed jobs.
getNumberOfQueuedJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getNumberOfQueuedJobs() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getNumberOfQueuedJobs() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getNumberOfQueuedJobs() - Method in interface org.apache.sling.event.jobs.Statistics
Number of jobs currently waiting in a queue.
getNumberOfRetries() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getNumberOfRetries() - Method in interface org.apache.sling.event.jobs.Job
The property to track the retry maximum retry count for jobs.
getOldQueue() - Method in class org.apache.sling.event.impl.jobs.jmx.QueueStatusEvent
 
getOrCreateBasePath(ResourceResolver, String) - Static method in class org.apache.sling.event.impl.support.ResourceHelper
 
getOrCreateResource(ResourceResolver, String, Map<String, Object>) - Static method in class org.apache.sling.event.impl.support.ResourceHelper
 
getOwnThreadPoolSize() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getOwnThreadPoolSize() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the size for the optional thread pool for this queue.
getPid() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getPosition() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.
 
getPosition() - Method in interface org.apache.sling.event.jobs.JobsIterator
Deprecated.
Returns the current position within the iterator.
getPotentialTargets(String, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Return the potential targets (Sling IDs) sorted by ID
getPreviousVersionAnonPath() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
getPreviousVersionIdentifiedPath() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
getPriority() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getPriority() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
getProcessingStarted() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getProcessingStarted() - Method in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains a calendar object specifying the date and time when this job has been started.
getProgressETA() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getProgressETA() - Method in interface org.apache.sling.event.jobs.Job
If the job is in processing, return the optional ETA for this job.
getProgressLog() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getProgressLog() - Method in interface org.apache.sling.event.jobs.Job
This method returns the optional progress log from the last job processing.
getProgressStepCount() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getProgressStepCount() - Method in interface org.apache.sling.event.jobs.Job
If the job is in processing, return the optional progress step count if available.
getProperties() - Method in class org.apache.sling.event.impl.jobs.JobImpl
Get all properties
getProperty(String) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getProperty(String, Class<T>) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getProperty(String, T) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getProperty(String) - Method in interface org.apache.sling.event.jobs.Job
Get the value of a property.
getProperty(String, Class<T>) - Method in interface org.apache.sling.event.jobs.Job
Get a named property and convert it into the given type.
getProperty(String, T) - Method in interface org.apache.sling.event.jobs.Job
Get a named property and convert it into the given type.
getPropertyNames() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getPropertyNames() - Method in interface org.apache.sling.event.jobs.Job
Get all property names.
getQueue() - Method in class org.apache.sling.event.impl.jobs.jmx.QueueStatusEvent
 
getQueue(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getQueue(String) - Method in class org.apache.sling.event.impl.jobs.queues.QueueManager
 
getQueue(String) - Method in interface org.apache.sling.event.jobs.JobManager
Return a queue with a specific name (if running)
getQueueConfigurationManager() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
getQueueInfo(String) - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Find the queue configuration for the job.
getQueueName() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getQueueName() - Method in interface org.apache.sling.event.jobs.Job
The name of the job queue processing this job.
getQueueNames() - Method in class org.apache.sling.event.impl.jobs.jmx.QueuesMBeanImpl
 
getQueueNames() - Method in interface org.apache.sling.event.jobs.jmx.QueuesMBean
 
getQueues() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getQueues() - Method in class org.apache.sling.event.impl.jobs.queues.QueueManager
 
getQueues() - Method in interface org.apache.sling.event.jobs.JobManager
Return an iterator for all available queues.
getQueueStatistics(String) - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsManager
Get a single queue statistics.
getRanking() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getRanking() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Get the ranking of this configuration.
getResourcePath() - Method in class org.apache.sling.event.impl.jobs.JobImpl
Get the full resource path.
getResourcePath() - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventConfiguration
 
getResourcePathWithSlash() - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventConfiguration
 
getResultMessage() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getResultMessage() - Method in interface org.apache.sling.event.jobs.Job
This method returns the message from the last job processing, regardless whether the processing failed, succeeded or was cancelled.
getRetryCount() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getRetryCount() - Method in interface org.apache.sling.event.jobs.Job
On first execution the value of this property is zero.
getRetryDelay(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
getRetryDelayInMs() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getRetryDelayInMs() - Method in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
 
getRetryDelayInMs() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
Return the retry delay in ms
getRetryDelayInMs() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the retry delay in ms
getScheduledEvent(String, String, String) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
getScheduledEvent(String, String, String) - Method in interface org.apache.sling.event.TimedEventStatusProvider
Deprecated.
Return the scheduled event with the given id.
getScheduledEvents(String, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
getScheduledEvents(String, Map<String, Object>...) - Method in interface org.apache.sling.event.TimedEventStatusProvider
Deprecated.
Return a list of currently scheduled events.
getScheduledJobs(String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
getScheduledJobs(String, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
getScheduledJobs() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getScheduledJobs(String, long, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getScheduledJobs(String, long, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
Get all scheduled jobs
getScheduledJobs() - Method in interface org.apache.sling.event.jobs.JobManager
Return all available job schedules.
getScheduledJobs(String, long, Map<String, Object>...) - Method in interface org.apache.sling.event.jobs.JobManager
Return all matching available job schedules.
getScheduledJobs(String) - Method in interface org.apache.sling.event.JobStatusProvider
getScheduledJobs(String, Map<String, Object>...) - Method in interface org.apache.sling.event.JobStatusProvider
getScheduledJobsPath(boolean) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get the scheduled jobs path
getSchedulerJobId() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
Get the scheduler job id
getSchedules() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
getSchedules() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Get all schedules for this job
getSerializedString() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getSize() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.
 
getSize() - Method in interface org.apache.sling.event.jobs.JobsIterator
Deprecated.
Returns the total number of jobs.
getSortedChildren(Logger, String, Resource) - Static method in class org.apache.sling.event.impl.jobs.Utility
Helper method to read all children of a resource and sort them by name
getStartDate() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getStartDate() - Method in interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
getStartTime() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getStartTime() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
getStartTime() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
getStartTime() - Method in interface org.apache.sling.event.jobs.Statistics
The time this service has been started
getState() - Method in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
Get the internal state
getState(String) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
getState(String) - Method in interface org.apache.sling.event.jobs.Queue
For monitoring purposes and possible extensions from the different queue types.
getStateInfo() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
getStateInfo() - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
getStateInfo() - Method in interface org.apache.sling.event.jobs.Queue
Return some information about the current state of the queue.
getStatistics() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
getStatistics() - Method in class org.apache.sling.event.impl.jobs.jmx.AllJobStatisticsMBean
 
getStatistics() - Method in class org.apache.sling.event.impl.jobs.jmx.QueueMBeanImpl
 
getStatistics() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Return our internal statistics object.
getStatistics() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
getStatistics() - Method in interface org.apache.sling.event.jobs.JobManager
Return statistics information about all queues.
getStatistics() - Method in interface org.apache.sling.event.jobs.Queue
Return statistics information about this queue.
getStoragePath(String, String, boolean) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get the storage path for finished jobs.
getStoredCancelledJobsPath() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
getStoredSuccessfulJobsPath() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
getTargetInstance() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getTargetInstance() - Method in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains the Sling instance ID of the instance where this job should be processed.
getThreadPriority() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getThreadPriority() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the thread priority for the job thread
getTopic() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getTopic() - Method in class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
 
getTopic() - Method in interface org.apache.sling.event.jobs.Job
The job topic.
getTopic() - Method in interface org.apache.sling.event.jobs.TopicStatistics
The topic this statistics is about.
getTopics() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getTopics() - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Return the topics information of this instance.
getTopics() - Method in class org.apache.sling.event.impl.jobs.queues.QueueJobCache
All topics of this queue.
getTopics() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
The list of topics this queue is bound to.
getTopicStatistics() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getTopicStatistics() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsManager
Get all topic statistics.
getTopicStatistics() - Method in interface org.apache.sling.event.jobs.JobManager
Return statistics information about job topics.
getTopologyCapabilities() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get the current topology capabilities.
getTopologyCapabilities() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Get the current capabilities
getType() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getType() - Method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
getType() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the queue type.
getType() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
Return the scheduling type
getUnassignedJobsPath() - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get the resource path for all unassigned jobs.
getUniqueId(String) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Get the unique job id
getUniquePath(String, String, String, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Create a unique job path (folder and name) for the job.
getValueMap(Resource) - Static method in class org.apache.sling.event.impl.support.ResourceHelper
 

H

handle(JobImpl) - Method in interface org.apache.sling.event.impl.jobs.JobTopicTraverser.JobCallback
Callback handle for a job.
handle(Resource) - Method in interface org.apache.sling.event.impl.jobs.JobTopicTraverser.ResourceCallback
Callback handle for a resource.
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.deprecated.EventAdminBridge
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.notifications.NewJobSender
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.queues.QueueManager
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsManager
Handle all job notification events and update the statistics.
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventReceiver
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
handleNewTopics(Set<String>) - Method in class org.apache.sling.event.impl.jobs.queues.QueueJobCache
Inform the queue cache about topics containing new jobs
handleTopologyEvent(TopologyEvent) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
handleTopologyEvent(TopologyEvent) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
hashCode() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
hashCode() - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager.QueueInfo
 
hashCode() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
hashCode() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
hasNext() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.
 
hasReadErrors() - Method in class org.apache.sling.event.impl.jobs.JobImpl
Did we have read errors?
HistoryCleanUpTask - Class in org.apache.sling.event.impl.jobs.tasks
Task to clean up the history, A clean up task can be configured with three properties: - age : only jobs older than this amount of minutes are removed (default is two days) - topic : only jobs with this topic are removed (default is no topic, meaning all jobs are removed) The value should either be a string or an array of string - state : only jobs in this state are removed (default is no state, meaning all jobs are removed) The value should either be a string or an array of string.
HistoryCleanUpTask() - Constructor for class org.apache.sling.event.impl.jobs.tasks.HistoryCleanUpTask
 
hourly(int) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
HOURLY(int) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
hourly(int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job hourly at the given minute.

I

ignoreException(Exception) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Helper method which just logs the exception in debug mode.
ignoreProperty(String) - Static method in class org.apache.sling.event.impl.support.ResourceHelper
Check if this property should be ignored
incQueued() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
New job in the queue
incrementProgressCount(int) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Update the progress by additionally marking the provided number of steps as finished.
info(String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(Marker, String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(Marker, String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(Marker, String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(Marker, String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
info(Marker, String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
initProgress(int, long) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Indicate that the job executor is able to report the progress.
InternalJobState - Enum in org.apache.sling.event.impl.jobs
The state of the job after it has been processed by a JobExecutor.
InternalQueueConfiguration - Class in org.apache.sling.event.impl.jobs.config
 
InternalQueueConfiguration() - Constructor for class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
InventoryPlugin - Class in org.apache.sling.event.impl.jobs.console
This is a inventory plugin displaying the active queues, some statistics and the configurations.
InventoryPlugin() - Constructor for class org.apache.sling.event.impl.jobs.console.InventoryPlugin
 
isActive() - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Is this object still active?
isActive(String) - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Is this instance still active?
isBridgedEvent() - Method in class org.apache.sling.event.impl.jobs.JobImpl
Is this a bridged event?
isDebugEnabled() - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isDebugEnabled(Marker) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isEmpty() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
isEmpty() - Method in class org.apache.sling.event.impl.jobs.queues.QueueJobCache
Check whether there are jobs for this queue
isErrorEnabled() - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isErrorEnabled(Marker) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isInfoEnabled() - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isInfoEnabled(Marker) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isJob(String) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
isJobEvent(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated.
isJobEvent(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
isJobProcessingEnabled() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
isJobProcessingEnabled() - Method in interface org.apache.sling.event.jobs.JobManager
Deprecated.
This method always returns true
isKeepJobs() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
isKeepJobs() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Whether successful jobs are kept for a complete history
isLeader() - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Is the current instance the leader?
isLocal(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated.
Event handlers should rather filter just for the property being available (remote) or missing (local)
isLocalJob(String) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
isLocalQueue() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
Deprecated.
isLocalQueue() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Deprecated.
This information is not used anymore
isLock(String) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
isNew() - Method in class org.apache.sling.event.impl.jobs.jmx.QueueStatusEvent
 
isOutdated() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Is the queue outdated?
isPreferRunOnCreationInstance() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
isPreferRunOnCreationInstance() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Prefer to run the job on the same instance it was created on.
isRemoved() - Method in class org.apache.sling.event.impl.jobs.jmx.QueueStatusEvent
 
isSame(Map<String, String>) - Method in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Is this capabilities the same as represented by the provided instance map?
isStopped() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
isStopped() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
If a job is stoppable, it should periodically check this method and stop processing if the method return true.
isStoragePath(String) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Check whether this is a storage path.
isSuspended() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
isSuspended() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
isSuspended() - Method in interface org.apache.sling.event.jobs.Queue
Is the queue currently suspended?
isSuspended() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Is the processing currently suspended?
isTraceEnabled() - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isTraceEnabled(Marker) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isUpdate() - Method in class org.apache.sling.event.impl.jobs.jmx.QueueStatusEvent
 
isValid() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
isWaiting - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Is the queue currently waiting(sleeping)
isWarnEnabled() - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
isWarnEnabled(Marker) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
iterator() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.
 

J

Job - Interface in org.apache.sling.event.jobs
A job Property Types In general all scalar types and all serializable classes are supported as property types.
Job.JobState - Enum in org.apache.sling.event.jobs
The current job state.
JOB_ID - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
JobBuilder - Interface in org.apache.sling.event.jobs
This is a builder interface to build jobs and scheduled jobs.
JobBuilder.ScheduleBuilder - Interface in org.apache.sling.event.jobs
This is a builder interface for creating schedule information
JobBuilderImpl - Class in org.apache.sling.event.impl.jobs
Fluent builder API
JobBuilderImpl(JobManagerImpl, String) - Constructor for class org.apache.sling.event.impl.jobs.JobBuilderImpl
 
JobBuilderImpl.ScheduleBuilderImpl - Class in org.apache.sling.event.impl.jobs
 
JobBuilderImpl.ScheduleBuilderImpl(String) - Constructor for class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
JobConsumer - Interface in org.apache.sling.event.jobs.consumer
A job consumer consumes a job.
JobConsumer.AsyncHandler - Interface in org.apache.sling.event.jobs.consumer
If the consumer decides to process the job asynchronously, this handler interface can be used to notify finished processing.
JobConsumer.JobResult - Enum in org.apache.sling.event.jobs.consumer
 
JobConsumerManager - Class in org.apache.sling.event.impl.jobs
This component manages/keeps track of all job consumer services.
JobConsumerManager() - Constructor for class org.apache.sling.event.impl.jobs.JobConsumerManager
 
jobConsumerManager - Variable in class org.apache.sling.event.impl.jobs.queues.QueueServices
 
JobExecutionContext - Interface in org.apache.sling.event.jobs.consumer
 
JobExecutionContext.ResultBuilder - Interface in org.apache.sling.event.jobs.consumer
 
JobExecutionResult - Interface in org.apache.sling.event.jobs.consumer
The status of a job after it has been processed by a JobExecutor.
JobExecutionResultImpl - Class in org.apache.sling.event.impl.jobs
The job execution result.
JobExecutionResultImpl(InternalJobState, String, Long) - Constructor for class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
Create a new result
JobExecutor - Interface in org.apache.sling.event.jobs.consumer
A job executor consumes a job.
JobHandler - Class in org.apache.sling.event.impl.jobs
This object adds actions to a JobImpl.
JobHandler(JobImpl, JobManagerConfiguration) - Constructor for class org.apache.sling.event.impl.jobs.JobHandler
 
JobImpl - Class in org.apache.sling.event.impl.jobs
This object encapsulates all information about a job.
JobImpl(String, String, String, Map<String, Object>) - Constructor for class org.apache.sling.event.impl.jobs.JobImpl
Create a new job instance
JobManager - Interface in org.apache.sling.event.jobs
The job manager is the heart of the job event handling.
JobManager.QueryType - Enum in org.apache.sling.event.jobs
The requested job types for the query.
JobManagerConfiguration - Class in org.apache.sling.event.impl.jobs.config
Configuration of the job handling
JobManagerConfiguration() - Constructor for class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
JobManagerImpl - Class in org.apache.sling.event.impl.jobs
Implementation of the job manager.
JobManagerImpl() - Constructor for class org.apache.sling.event.impl.jobs.JobManagerImpl
 
JobProcessor - Interface in org.apache.sling.event
Deprecated.
Use org.apache.sling.event.jobs.JobProcessor
JobProcessor - Interface in org.apache.sling.event.jobs
Deprecated.
- Use the new JobConsumer interface instead.
JobSchedulerImpl - Class in org.apache.sling.event.impl.jobs
A scheduler for scheduling jobs
JobSchedulerImpl(JobManagerConfiguration, Scheduler, JobManagerImpl) - Constructor for class org.apache.sling.event.impl.jobs.JobSchedulerImpl
 
JobsIterator - Interface in org.apache.sling.event.jobs
JobsIterator - Interface in org.apache.sling.event
Deprecated. 
JobsIteratorImpl - Class in org.apache.sling.event.impl.jobs.deprecated
Deprecated. 
JobsIteratorImpl(JobsIterator) - Constructor for class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.
 
JobStatusNotifier - Interface in org.apache.sling.event.impl.jobs.deprecated
 
JobStatusNotifier.NotifierContext - Class in org.apache.sling.event.impl.jobs.deprecated
 
JobStatusNotifier.NotifierContext(JobStatusNotifier) - Constructor for class org.apache.sling.event.impl.jobs.deprecated.JobStatusNotifier.NotifierContext
 
JobStatusProvider - Interface in org.apache.sling.event
Deprecated. 
JobStatusProviderImpl - Class in org.apache.sling.event.impl.jobs.deprecated
Deprecated. 
JobStatusProviderImpl() - Constructor for class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
JobTopicTraverser - Class in org.apache.sling.event.impl.jobs
The job topic traverser is an utility class to traverse all jobs of a specific topic in order of creation.
JobTopicTraverser() - Constructor for class org.apache.sling.event.impl.jobs.JobTopicTraverser
 
JobTopicTraverser.JobCallback - Interface in org.apache.sling.event.impl.jobs
Callback called for each found job.
JobTopicTraverser.ResourceCallback - Interface in org.apache.sling.event.impl.jobs
Callback called for each found resource.
JobUtil - Class in org.apache.sling.event.jobs
Deprecated. 
JobUtil.JobPriority - Enum in org.apache.sling.event.jobs
Deprecated. 

K

keys() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
keySet() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 

L

log(String, Object...) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
log(String, Object...) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Log a message.
logger - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
The logger.

M

MAIN_QUEUE_NAME - Static variable in class org.apache.sling.event.impl.jobs.config.MainQueueConfiguration
 
MainQueueConfiguration - Class in org.apache.sling.event.impl.jobs.config
This is the configuration for the main queue.
MainQueueConfiguration() - Constructor for class org.apache.sling.event.impl.jobs.config.MainQueueConfiguration
 
match(String) - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
Check if the queue processes the event.
match(String) - Method in class org.apache.sling.event.impl.support.ExactTopicMatcher
 
match(String) - Method in class org.apache.sling.event.impl.support.PackageTopicMatcher
 
match(String) - Method in class org.apache.sling.event.impl.support.SubPackagesTopicMatcher
 
match(String) - Method in interface org.apache.sling.event.impl.support.TopicMatcher
Check if the topic matches and return the variable part - null if not matching.
MATCH_ALL - Static variable in class org.apache.sling.event.impl.support.TopicMatcherHelper
 
message(String) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
Add an optional processing message.
modified(BundleContext, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
 
monthly(int, int, int) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
MONTHLY(int, int, int) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
monthly(int, int, int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job monthly, the time needs to be specified in addition.

N

NewJobSender - Class in org.apache.sling.event.impl.jobs.notifications
This component receives resource added events and sends a job created event.
NewJobSender() - Constructor for class org.apache.sling.event.impl.jobs.notifications.NewJobSender
 
next() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.
 
NOTIFICATION_PROPERTY_JOB_ID - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
Use NotificationConstants#NOTIFICATION_PROPERTY_JOB_ID
NOTIFICATION_PROPERTY_JOB_ID - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Property containing the unique job ID.
NOTIFICATION_PROPERTY_JOB_NAME - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
NOTIFICATION_PROPERTY_JOB_TOPIC - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
Use NotificationConstants#NOTIFICATION_PROPERTY_JOB_TOPIC
NOTIFICATION_PROPERTY_JOB_TOPIC - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Property containing the job topic.
NotificationConstants - Class in org.apache.sling.event.jobs
This class contains constants for event notifications.
NotificationUtility - Class in org.apache.sling.event.impl.jobs.notifications
 
NotificationUtility() - Constructor for class org.apache.sling.event.impl.jobs.notifications.NotificationUtility
 
notifyFinished(boolean) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
notifyFinished(boolean) - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
notifyFinished(boolean) - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
NUMBER_OF_PROCESSORS - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 

O

ok() - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer.AsyncHandler
 
OrderedJobQueue - Class in org.apache.sling.event.impl.jobs.queues
An ordered job queue is processing the queue FIFO in a serialized way.
OrderedJobQueue(String, InternalQueueConfiguration, QueueServices, Set<String>) - Constructor for class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
org.apache.sling.event - package org.apache.sling.event
 
org.apache.sling.event.impl - package org.apache.sling.event.impl
 
org.apache.sling.event.impl.jobs - package org.apache.sling.event.impl.jobs
 
org.apache.sling.event.impl.jobs.config - package org.apache.sling.event.impl.jobs.config
 
org.apache.sling.event.impl.jobs.console - package org.apache.sling.event.impl.jobs.console
 
org.apache.sling.event.impl.jobs.deprecated - package org.apache.sling.event.impl.jobs.deprecated
 
org.apache.sling.event.impl.jobs.jmx - package org.apache.sling.event.impl.jobs.jmx
 
org.apache.sling.event.impl.jobs.notifications - package org.apache.sling.event.impl.jobs.notifications
 
org.apache.sling.event.impl.jobs.queues - package org.apache.sling.event.impl.jobs.queues
 
org.apache.sling.event.impl.jobs.stats - package org.apache.sling.event.impl.jobs.stats
 
org.apache.sling.event.impl.jobs.tasks - package org.apache.sling.event.impl.jobs.tasks
 
org.apache.sling.event.impl.jobs.timed - package org.apache.sling.event.impl.jobs.timed
 
org.apache.sling.event.impl.support - package org.apache.sling.event.impl.support
 
org.apache.sling.event.jobs - package org.apache.sling.event.jobs
 
org.apache.sling.event.jobs.consumer - package org.apache.sling.event.jobs.consumer
 
org.apache.sling.event.jobs.jmx - package org.apache.sling.event.jobs.jmx
 
outdate() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Outdate this queue.

P

PackageTopicMatcher - Class in org.apache.sling.event.impl.support
Package matcher - the topic must be in the same package.
PackageTopicMatcher(String) - Constructor for class org.apache.sling.event.impl.support.PackageTopicMatcher
 
ParallelJobQueue - Class in org.apache.sling.event.impl.jobs.queues
The default parallel job queue processing the entries FIFO.
ParallelJobQueue(String, InternalQueueConfiguration, QueueServices, Set<String>) - Constructor for class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
persistJobProperties(String...) - Method in class org.apache.sling.event.impl.jobs.JobHandler
Update the property of a job in the resource tree
prepare(Queue) - Method in class org.apache.sling.event.impl.jobs.JobImpl
Prepare a new job execution
print(PrintWriter, Format, boolean) - Method in class org.apache.sling.event.impl.jobs.console.InventoryPlugin
 
process(Job) - Method in class org.apache.sling.event.impl.jobs.console.WebConsolePlugin
 
process(Job) - Method in class org.apache.sling.event.impl.jobs.deprecated.EventAdminBridge
 
process(Job, JobExecutionContext) - Method in class org.apache.sling.event.impl.jobs.tasks.HistoryCleanUpTask
 
process(Job) - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer
Execute the job.
process(Job, JobExecutionContext) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutor
Execute the job.
process(Event) - Method in interface org.apache.sling.event.jobs.JobProcessor
Deprecated.
Execute the job.
processEvent(Event, ScheduleInfo) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
Process the event.
processJob(Event, JobProcessor) - Static method in class org.apache.sling.event.EventUtil
processJob(Event, JobProcessor) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new JobConsumer interface instead.
PROP_KEEP_JOBS - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_MAX_PARALLEL - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_NAME - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_PREFER_RUN_ON_CREATION_INSTANCE - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_PRIORITY - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_RETRIES - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_RETRY_DELAY - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_THREAD_POOL_SIZE - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_TOPICS - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
PROP_TYPE - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
properties(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl
 
properties(Map<String, Object>) - Method in interface org.apache.sling.event.jobs.JobBuilder
Set the optional configuration properties for the job.
PROPERTY_APPLICATION - Static variable in class org.apache.sling.event.EventUtil
Deprecated. 
PROPERTY_BACKGROUND_LOAD_DELAY - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
The background loader waits this time of seconds after startup before loading events from the repository.
PROPERTY_BRIDGED_EVENT - Static variable in class org.apache.sling.event.impl.jobs.JobImpl
Internal job property if this is an bridged event (event admin).
PROPERTY_DELAY_OVERRIDE - Static variable in class org.apache.sling.event.impl.jobs.JobImpl
Internal job property containing optional delay override.
PROPERTY_DISABLE_DISTRIBUTION - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Configuration switch for distributing the jobs.
PROPERTY_DISTRIBUTE - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
s
PROPERTY_EVENT_ID - Static variable in interface org.apache.sling.event.JobStatusProvider
Deprecated.
PROPERTY_EVENT_ID - Static variable in interface org.apache.sling.event.TimedEventStatusProvider
Deprecated.
This is a unique identifier which can be used to cancel the job.
PROPERTY_FINISHED_DATE - Static variable in interface org.apache.sling.event.jobs.Job
This property contains the finished date once a job is marked as finished.
PROPERTY_FINISHED_STATE - Static variable in class org.apache.sling.event.impl.jobs.JobImpl
This property contains the finished state of a job once it's marked as finished.
PROPERTY_JOB_APPLICATION - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
PROPERTY_JOB_ASYNC_HANDLER - Static variable in interface org.apache.sling.event.jobs.consumer.JobConsumer
Job property containing an asynchronous handler.
PROPERTY_JOB_CREATED - Static variable in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains a calendar object specifying the date and time when this job has been created.
PROPERTY_JOB_CREATED - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
PROPERTY_JOB_CREATED_APPLICATION - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
PROPERTY_JOB_CREATED_INSTANCE - Static variable in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains the Sling instance ID of the instance where this job has been created.
PROPERTY_JOB_DESCRIPTION - Static variable in interface org.apache.sling.event.jobs.Job
This is an optional property containing a human readable description for the job
PROPERTY_JOB_ID - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
PROPERTY_JOB_ID - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
PROPERTY_JOB_NAME - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
PROPERTY_JOB_PARALLEL - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_PARALLEL - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. 
PROPERTY_JOB_PRIORITY - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_PRIORITY - Static variable in interface org.apache.sling.event.jobs.Job
Deprecated. 
PROPERTY_JOB_PRIORITY - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
PROPERTY_JOB_PROGRESS_ETA - Static variable in interface org.apache.sling.event.jobs.Job
This property contains the optional ETA for a job.
PROPERTY_JOB_PROGRESS_LOG - Static variable in interface org.apache.sling.event.jobs.Job
This property contains the optional output log of a job consumer.
PROPERTY_JOB_PROGRESS_STEP - Static variable in interface org.apache.sling.event.jobs.Job
This property contains optional progress information about a job, the number of completed steps.
PROPERTY_JOB_PROGRESS_STEPS - Static variable in interface org.apache.sling.event.jobs.Job
This property contains optional progress information about a job, the number of steps the job consumer will perform.
PROPERTY_JOB_QUEUE_NAME - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_QUEUE_NAME - Static variable in interface org.apache.sling.event.jobs.Job
The name of the job queue processing this job.
PROPERTY_JOB_QUEUE_NAME - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
PROPERTY_JOB_QUEUE_ORDERED - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_QUEUE_ORDERED - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. 
PROPERTY_JOB_RETRIES - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_RETRIES - Static variable in interface org.apache.sling.event.jobs.Job
The property to track the retry maximum retry count for jobs.
PROPERTY_JOB_RETRIES - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
PROPERTY_JOB_RETRY_COUNT - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_RETRY_COUNT - Static variable in interface org.apache.sling.event.jobs.Job
The property to track the retry count for jobs.
PROPERTY_JOB_RETRY_COUNT - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
PROPERTY_JOB_RETRY_DELAY - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_RETRY_DELAY - Static variable in interface org.apache.sling.event.jobs.Job
The property to set a retry delay.
PROPERTY_JOB_RETRY_DELAY - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new Job interface instead.
PROPERTY_JOB_RUN_LOCAL - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_RUN_LOCAL - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. 
PROPERTY_JOB_STARTED_TIME - Static variable in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains a calendar object specifying the date and time when this job has been started.
PROPERTY_JOB_TARGET_INSTANCE - Static variable in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains the Sling instance ID of the instance where this job should be processed.
PROPERTY_JOB_TITLE - Static variable in interface org.apache.sling.event.jobs.Job
This is an optional property containing a human readable title for the job
PROPERTY_JOB_TOPIC - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_JOB_TOPIC - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
PROPERTY_JOB_TOPIC - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
PROPERTY_LOCK_CREATED - Static variable in class org.apache.sling.event.impl.jobs.Utility
 
PROPERTY_LOCK_CREATED_APP - Static variable in class org.apache.sling.event.impl.jobs.Utility
 
PROPERTY_MARKER_READ_ERROR_LIST - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
PROPERTY_NOTIFICATION_JOB - Static variable in class org.apache.sling.event.EventUtil
PROPERTY_NOTIFICATION_JOB - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. 
PROPERTY_REPOSITORY_PATH - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
The path where all jobs are stored.
PROPERTY_RESOURCE_PATH - Static variable in class org.apache.sling.event.impl.jobs.JobImpl
Internal job property containing the resource path.
PROPERTY_RESULT_MESSAGE - Static variable in interface org.apache.sling.event.jobs.Job
This property contains the optional result message of a job consumer.
PROPERTY_SCHEDULE_INFO - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
PROPERTY_SCHEDULE_INFO_TYPE - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
PROPERTY_SCHEDULE_NAME - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
PROPERTY_SCHEDULE_SUSPENDED - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
PROPERTY_SCHEDULED_JOBS_PATH - Static variable in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Configuration property for the scheduled jobs path.
PROPERTY_TIME - Static variable in class org.apache.sling.event.impl.jobs.notifications.NotificationUtility
Event property containing the time for job start and job finished events.
PROPERTY_TIMED_EVENT_DATE - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
Use scheduled jobs instead
PROPERTY_TIMED_EVENT_ID - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
Use scheduled jobs instead
PROPERTY_TIMED_EVENT_PERIOD - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
Use scheduled jobs instead
PROPERTY_TIMED_EVENT_SCHEDULE - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
Use scheduled jobs instead
PROPERTY_TIMED_EVENT_TOPIC - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
Use scheduled jobs instead
PROPERTY_TOPICS - Static variable in class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
 
PROPERTY_TOPICS - Static variable in interface org.apache.sling.event.jobs.consumer.JobConsumer
Service registration property defining the jobs this consumer is able to process.
PROPERTY_TOPICS - Static variable in interface org.apache.sling.event.jobs.consumer.JobExecutor
Service registration property defining the jobs this executor is able to process.
put(String, Object) - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
putAll(Map<? extends String, ? extends Object>) - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 

Q

queryAllJobs(String, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
queryAllJobs(String, Map<String, Object>...) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
Return all jobs either running or scheduled.
queryCurrentJobs(String, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
queryCurrentJobs(String, Map<String, Object>...) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
Return the jobs which are currently in processing.
queryJobs(JobManager.QueryType, String, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
queryJobs(JobManager.QueryType, String, long, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
queryJobs(JobManager.QueryType, String, Map<String, Object>...) - Method in interface org.apache.sling.event.jobs.JobManager
queryJobs(JobManager.QueryType, String, long, Map<String, Object>...) - Method in interface org.apache.sling.event.jobs.JobManager
queryScheduledJobs(String, Map<String, Object>...) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
queryScheduledJobs(String, Map<String, Object>...) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
Return a list of currently scheduled jobs.
Queue - Interface in org.apache.sling.event.jobs
This is a job queue processing job events.
queueConfiguration - Variable in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager.QueueInfo
 
QueueConfiguration - Interface in org.apache.sling.event.jobs
The configuration of a queue.
QueueConfiguration.ThreadPriority - Enum in org.apache.sling.event.jobs
The thread priority.
QueueConfiguration.Type - Enum in org.apache.sling.event.jobs
The queue type.
QueueConfigurationManager - Class in org.apache.sling.event.impl.jobs.config
The queue manager manages queue configurations.
QueueConfigurationManager() - Constructor for class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
 
QueueConfigurationManager.QueueInfo - Class in org.apache.sling.event.impl.jobs.config
 
QueueConfigurationManager.QueueInfo() - Constructor for class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager.QueueInfo
 
queued - Variable in class org.apache.sling.event.impl.jobs.JobHandler
 
QueueJobCache - Class in org.apache.sling.event.impl.jobs.queues
The queue job cache caches jobs per queue based on the topics the queue is actively processing.
QueueJobCache(JobManagerConfiguration, QueueConfiguration.Type, Set<String>) - Constructor for class org.apache.sling.event.impl.jobs.queues.QueueJobCache
Create a new queue job cache
QueueManager - Class in org.apache.sling.event.impl.jobs.queues
Implementation of the job manager.
QueueManager() - Constructor for class org.apache.sling.event.impl.jobs.queues.QueueManager
 
QueueMBeanImpl - Class in org.apache.sling.event.impl.jobs.jmx
An MBean that provides statistics from
QueueMBeanImpl(Queue) - Constructor for class org.apache.sling.event.impl.jobs.jmx.QueueMBeanImpl
 
queueName - Variable in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager.QueueInfo
 
queueName - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
The queue name.
QueueServices - Class in org.apache.sling.event.impl.jobs.queues
 
QueueServices() - Constructor for class org.apache.sling.event.impl.jobs.queues.QueueServices
 
QueuesMBean - Interface in org.apache.sling.event.jobs.jmx
A Marker interface to allow the implementation to register as a service with the JMX whiteboard.
QueuesMBeanImpl - Class in org.apache.sling.event.impl.jobs.jmx
 
QueuesMBeanImpl() - Constructor for class org.apache.sling.event.impl.jobs.jmx.QueuesMBeanImpl
 
QueueStatusEvent - Class in org.apache.sling.event.impl.jobs.jmx
 
QueueStatusEvent(Queue, Queue) - Constructor for class org.apache.sling.event.impl.jobs.jmx.QueueStatusEvent
 

R

readJob(Logger, Resource) - Static method in class org.apache.sling.event.impl.jobs.Utility
Read a job
reassign() - Method in class org.apache.sling.event.impl.jobs.JobHandler
Reassign to a new instance.
registerListener(String, JobExecutor, JobExecutionContext) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
 
release() - Method in class org.apache.sling.event.impl.EventingThreadPool
 
remove(Object) - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
remove() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.
 
removeAll() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
removeAll() - Method in interface org.apache.sling.event.jobs.Queue
Remove all outstanding jobs and delete them.
removeFromRetryList() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
removeJob(String, String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
removeJob(String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
removeJob(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
removeJob(String) - Method in interface org.apache.sling.event.jobs.JobManager
removeJob(String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
Cancel this job.
removeJob(String, String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
Cancel this job.
removeJobById(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
removeJobById(String) - Method in interface org.apache.sling.event.jobs.JobManager
Removes the job even if it is currently in processing.
removeJobFromRetryList(Job) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
 
removeListener(ConfigurationChangeListener) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Remove a topology aware listener
removeListener() - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Remove the config listener.
reschedule() - Method in class org.apache.sling.event.impl.jobs.JobHandler
Reschedule the job Update the retry count and remove the started time.
reschedule(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
reschedule(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
reschedule(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
reschedule(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.QueueJobCache
Reschedule a job Reschedule the job and add it back into the cache.
reschedule() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
reschedule() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Reschedule this job with a new rescheduling information.
rescheduleJob(Event) - Static method in class org.apache.sling.event.EventUtil
rescheduleJob(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated.
- Use the new JobConsumer interface instead.
reset() - Method in class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
reset() - Method in class org.apache.sling.event.impl.jobs.jmx.EmptyStatistics
 
reset() - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
reset() - Method in interface org.apache.sling.event.jobs.Statistics
Clear all collected statistics and set the starting time to the current time.
RESOURCE_PROPERTY_TE_DATE - Static variable in class org.apache.sling.event.impl.jobs.timed.TimedEventReceiver
 
RESOURCE_PROPERTY_TE_EXPRESSION - Static variable in class org.apache.sling.event.impl.jobs.timed.TimedEventReceiver
 
RESOURCE_PROPERTY_TE_PERIOD - Static variable in class org.apache.sling.event.impl.jobs.timed.TimedEventReceiver
 
RESOURCE_TYPE_EVENT - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
RESOURCE_TYPE_FOLDER - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
RESOURCE_TYPE_JOB - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
 
RESOURCE_TYPE_LOCK - Static variable in class org.apache.sling.event.impl.jobs.Utility
 
RESOURCE_TYPE_SCHEDULED_JOB - Static variable in class org.apache.sling.event.impl.support.ResourceHelper
We use the same resource type as for timed events.
ResourceHelper - Class in org.apache.sling.event.impl.support
 
ResourceHelper() - Constructor for class org.apache.sling.event.impl.support.ResourceHelper
 
restart() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
restart() - Method in interface org.apache.sling.event.jobs.JobManager
Deprecated.
This method does nothing
result() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Build a result for the processing.
resume() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
resume() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
resume() - Method in interface org.apache.sling.event.jobs.Queue
Resume a suspended queue.
resume() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Resume job processing.
retry() - Method in class org.apache.sling.event.impl.jobs.JobImpl
Update the information for a retry
retryJobById(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
retryJobById(String) - Method in interface org.apache.sling.event.jobs.JobManager
Retry a cancelled job.
run() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
This method is invoked periodically by the scheduler.
run() - Method in class org.apache.sling.event.impl.jobs.queues.QueueManager
This method is invoked periodically by the scheduler.
run(TopologyCapabilities, boolean, boolean) - Method in class org.apache.sling.event.impl.jobs.tasks.CheckTopologyTask
One maintenance run
run(TopologyCapabilities, long) - Method in class org.apache.sling.event.impl.jobs.tasks.CleanUpTask
One maintenance run
run(JobManagerConfiguration) - Method in class org.apache.sling.event.impl.jobs.tasks.FindUnfinishedJobsTask
 
run(JobManagerConfiguration, TopologyCapabilities) - Method in class org.apache.sling.event.impl.jobs.tasks.UpgradeTask
Upgrade
runInBackground() - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
 
runInBackground() - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
running - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Are we still running?

S

schedule() - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl
 
schedule(String) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl
 
schedule() - Method in interface org.apache.sling.event.jobs.JobBuilder
Schedule the job
ScheduledJobInfo - Interface in org.apache.sling.event.jobs
Information about a scheduled job
ScheduledJobInfoImpl - Class in org.apache.sling.event.impl.jobs
 
ScheduledJobInfoImpl(JobSchedulerImpl, String, Map<String, Object>, String) - Constructor for class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
ScheduleInfo - Interface in org.apache.sling.event.jobs
Scheduling information.
ScheduleInfo.ScheduleType - Enum in org.apache.sling.event.jobs
 
ScheduleInfoImpl - Class in org.apache.sling.event.impl.support
 
scheduler - Variable in class org.apache.sling.event.impl.jobs.queues.QueueServices
 
sendAcknowledge(Event) - Method in interface org.apache.sling.event.impl.jobs.deprecated.JobStatusNotifier
Send an acknowledge message that someone is processing the job.
sendAcknowledge(Event) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
sendEvent(QueueStatusEvent) - Method in class org.apache.sling.event.impl.jobs.jmx.QueuesMBeanImpl
 
sendNotification(EventAdmin, String, String, String, Map<String, Object>, Long) - Static method in class org.apache.sling.event.impl.jobs.notifications.NotificationUtility
Helper method for sending the notification events.
sendNotification(EventAdmin, String, Job, Long) - Static method in class org.apache.sling.event.impl.jobs.notifications.NotificationUtility
Helper method for sending the notification events.
services - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Services used by the queues.
setProgress(int) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
setProperty(String, Object) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
setSuspended(ScheduledJobInfoImpl, boolean) - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
 
shouldDistribute(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated. 
size() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
skip(long) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.
 
skip(long) - Method in interface org.apache.sling.event.jobs.JobsIterator
Deprecated.
Skip a number of jobs.
start() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Start the job queue.
start(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Start processing of a new job.
start(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
start(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
started - Variable in class org.apache.sling.event.impl.jobs.JobHandler
 
startProcessing(Queue) - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
startProgress(int, long) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
Statistics - Interface in org.apache.sling.event.jobs
Statistic information.
StatisticsImpl - Class in org.apache.sling.event.impl.jobs.stats
Implementation of the statistics.
StatisticsImpl() - Constructor for class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
StatisticsImpl(long) - Constructor for class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
 
statisticsManager - Variable in class org.apache.sling.event.impl.jobs.queues.QueueServices
 
StatisticsManager - Class in org.apache.sling.event.impl.jobs.stats
The statistics manager keeps track of all statistics related tasks.
StatisticsManager() - Constructor for class org.apache.sling.event.impl.jobs.stats.StatisticsManager
 
StatisticsMBean - Interface in org.apache.sling.event.jobs.jmx
 
stop() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
stopJob(JobImpl) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
stopJobById(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
stopJobById(String) - Method in interface org.apache.sling.event.jobs.JobManager
Stop a job.
SubPackagesTopicMatcher - Class in org.apache.sling.event.impl.support
Sub package matcher - the topic must be in the same package or a sub package.
SubPackagesTopicMatcher(String) - Constructor for class org.apache.sling.event.impl.support.SubPackagesTopicMatcher
 
SUCCEEDED - Static variable in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
Constant object for the success case.
succeeded() - Method in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
 
succeeded() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
The job processing finished successfully.
succeeded() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
If this returns true the job processing finished successfully.
supportsBridgedEvents() - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Does this instance supports bridged events?
suspend() - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
suspend() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
suspend() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
suspend() - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Suspend this scheduling by default.
suspend() - Method in interface org.apache.sling.event.jobs.Queue
Suspend the queue - when a queue is suspended it stops processing jobs - however already started jobs are finished (but not rescheduled).
suspend() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Suspend this job scheduling.

T

targetId - Variable in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager.QueueInfo
 
TestLogger - Class in org.apache.sling.event.impl.jobs
 
TestLogger(Logger) - Constructor for class org.apache.sling.event.impl.jobs.TestLogger
 
THREAD_POOL - Static variable in class org.apache.sling.event.impl.support.Environment
Global thread pool.
threadPoolManager - Variable in class org.apache.sling.event.impl.jobs.queues.QueueServices
 
TIMED_EVENT_RESOURCE_TYPE - Static variable in class org.apache.sling.event.impl.jobs.timed.TimedEventReceiver
 
TimedEventConfiguration - Class in org.apache.sling.event.impl.jobs.timed
An event handler for timed events.
TimedEventConfiguration() - Constructor for class org.apache.sling.event.impl.jobs.timed.TimedEventConfiguration
 
TimedEventReceiver - Class in org.apache.sling.event.impl.jobs.timed
An event handler for timed events.
TimedEventReceiver() - Constructor for class org.apache.sling.event.impl.jobs.timed.TimedEventReceiver
 
TimedEventSender - Class in org.apache.sling.event.impl.jobs.timed
An event handler for timed events.
TimedEventSender() - Constructor for class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
TimedEventStatusProvider - Interface in org.apache.sling.event
Deprecated.
Use scheduled jobs instead
toEvent(Job) - Static method in class org.apache.sling.event.impl.jobs.Utility
Create an event from a job
TOPIC_JOB - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
TOPIC_JOB - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
TOPIC_JOB_ADDED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is added.
TOPIC_JOB_CANCELLED - Static variable in class org.apache.sling.event.EventUtil
TOPIC_JOB_CANCELLED - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
Use NotificationConstants#TOPIC_JOB_CANCELLED
TOPIC_JOB_CANCELLED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is cancelled.
TOPIC_JOB_FAILED - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
TOPIC_JOB_FAILED - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
Use NotificationConstants#TOPIC_JOB_FAILED
TOPIC_JOB_FAILED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job failed.
TOPIC_JOB_FINISHED - Static variable in class org.apache.sling.event.EventUtil
TOPIC_JOB_FINISHED - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
Use NotificationConstants#TOPIC_JOB_FINISHED
TOPIC_JOB_FINISHED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is finished.
TOPIC_JOB_REMOVED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is permanently removed.
TOPIC_JOB_STARTED - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
TOPIC_JOB_STARTED - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.
Use NotificationConstants#TOPIC_JOB_STARTED
TOPIC_JOB_STARTED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is started.
TOPIC_TIMED_EVENT - Static variable in class org.apache.sling.event.EventUtil
Deprecated.
Use scheduled jobs instead
TopicMatcher - Interface in org.apache.sling.event.impl.support
Interface for topic matchers
TopicMatcherHelper - Class in org.apache.sling.event.impl.support
 
TopicMatcherHelper() - Constructor for class org.apache.sling.event.impl.support.TopicMatcherHelper
 
TopicStatistics - Interface in org.apache.sling.event.jobs
Statistic information about a topic.
TopicStatisticsImpl - Class in org.apache.sling.event.impl.jobs.stats
Implementation of the statistics.
TopicStatisticsImpl(String) - Constructor for class org.apache.sling.event.impl.jobs.stats.TopicStatisticsImpl
Constructor.
TopologyCapabilities - Class in org.apache.sling.event.impl.jobs.config
The capabilities of a topology.
TopologyCapabilities(TopologyView, JobManagerConfiguration) - Constructor for class org.apache.sling.event.impl.jobs.config.TopologyCapabilities
Create a new instance
TopologyCapabilities.InstanceDescriptionComparator - Class in org.apache.sling.event.impl.jobs.config
 
TopologyCapabilities.InstanceDescriptionComparator(String) - Constructor for class org.apache.sling.event.impl.jobs.config.TopologyCapabilities.InstanceDescriptionComparator
 
toString() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
toString(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated.
The new event admin version provides a better toString() method
toString() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
toString() - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager.QueueInfo
 
toString() - Method in class org.apache.sling.event.impl.jobs.JobExecutionResultImpl
 
toString() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
toString() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
toString(String, String, Map<String, Object>) - Static method in class org.apache.sling.event.impl.jobs.Utility
Improved toString method for a job.
toString(Job) - Static method in class org.apache.sling.event.impl.jobs.Utility
Improved toString method for a job.
toString() - Method in class org.apache.sling.event.impl.support.ExactTopicMatcher
 
toString() - Method in class org.apache.sling.event.impl.support.PackageTopicMatcher
 
toString() - Method in class org.apache.sling.event.impl.support.SubPackagesTopicMatcher
 
trace(String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(Marker, String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(Marker, String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(Marker, String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(Marker, String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
trace(Marker, String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
traverse(Logger, Resource, JobTopicTraverser.JobCallback) - Static method in class org.apache.sling.event.impl.jobs.JobTopicTraverser
Traverse the topic and call the callback for each found job.
traverse(Logger, Resource, JobTopicTraverser.ResourceCallback) - Static method in class org.apache.sling.event.impl.jobs.JobTopicTraverser
Traverse the topic and call the callback for each found resource.
tryToClose() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Check if the queue can be closed

U

unbindConfig(InternalQueueConfiguration) - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Remove a queue configuration.
unbindJobConsumer(ServiceReference) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Unbind a consumer
unbindJobExecutor(ServiceReference) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Unbind a executor
unbindThreadPool(EventingThreadPool) - Method in class org.apache.sling.event.impl.EnvironmentComponent
 
unregisterListener(String) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
 
unschedule(ScheduledJobInfoImpl) - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
 
unschedule() - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
unschedule() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Unschedule this scheduled job.
update(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.config.JobManagerConfiguration
Update with a new configuration
update(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.config.MainQueueConfiguration
Configure this component.
update(long) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
update(boolean, List<ScheduleInfo>) - Method in class org.apache.sling.event.impl.jobs.ScheduledJobInfoImpl
 
updateConfig(InternalQueueConfiguration) - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Update a queue configuration.
updateProgress(long) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Update the progress to the new ETA.
updateQueueInfo(Queue) - Method in class org.apache.sling.event.impl.jobs.JobImpl
Update information about the queue.
UpgradeTask - Class in org.apache.sling.event.impl.jobs.tasks
Upgrade task Upgrade jobs from earlier versions to the new format.
UpgradeTask() - Constructor for class org.apache.sling.event.impl.jobs.tasks.UpgradeTask
 
Utility - Class in org.apache.sling.event.impl.jobs
 
Utility() - Constructor for class org.apache.sling.event.impl.jobs.Utility
 

V

valueOf(String) - Static method in enum org.apache.sling.event.EventUtil.JobPriority
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sling.event.impl.jobs.InternalJobState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sling.event.jobs.consumer.JobConsumer.JobResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sling.event.jobs.Job.JobState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sling.event.jobs.JobManager.QueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sling.event.jobs.JobUtil.JobPriority
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sling.event.jobs.QueueConfiguration.ThreadPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sling.event.jobs.QueueConfiguration.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sling.event.jobs.ScheduleInfo.ScheduleType
Returns the enum constant of this type with the specified name.
values() - Method in class org.apache.sling.event.EventPropertiesMap
Deprecated.
 
values() - Static method in enum org.apache.sling.event.EventUtil.JobPriority
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sling.event.impl.jobs.InternalJobState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sling.event.jobs.consumer.JobConsumer.JobResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sling.event.jobs.Job.JobState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sling.event.jobs.JobManager.QueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sling.event.jobs.JobUtil.JobPriority
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sling.event.jobs.QueueConfiguration.ThreadPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sling.event.jobs.QueueConfiguration.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sling.event.jobs.ScheduleInfo.ScheduleType
Returns an array containing the constants of this enum type, in the order they are declared.

W

wakeUpJobQueue(String) - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusProviderImpl
Deprecated.
 
wakeUpJobQueue(String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated.
Wake up the named job queue.
wakeUpQueue(Set<String>) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Inform the queue about a job for the topic
warn(String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(Marker, String) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(Marker, String, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(Marker, String, Object, Object) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(Marker, String, Object[]) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
warn(Marker, String, Throwable) - Method in class org.apache.sling.event.impl.jobs.TestLogger
 
WebConsolePlugin - Class in org.apache.sling.event.impl.jobs.console
This is a web console plugin displaying the active queues, some statistics and the configurations.
WebConsolePlugin() - Constructor for class org.apache.sling.event.impl.jobs.console.WebConsolePlugin
 
weekly(int, int, int) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
WEEKLY(int, int, int) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
weekly(int, int, int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job weekly, the time needs to be specified in addition.
writeJob(String, String, Map<String, Object>, String, boolean, List<ScheduleInfoImpl>) - Method in class org.apache.sling.event.impl.jobs.JobSchedulerImpl
Write a schedule job to the resource tree.

Y

yearly(int, int, int, int) - Method in class org.apache.sling.event.impl.jobs.JobBuilderImpl.ScheduleBuilderImpl
 
YEARLY(int, int, int, int) - Static method in class org.apache.sling.event.impl.support.ScheduleInfoImpl
 
yearly(int, int, int, int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job yearly, the time needs to be specified in addition.
A B C D E F G H I J K L M N O P Q R S T U V W Y 

Copyright © 2007–2014 The Apache Software Foundation. All rights reserved.