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

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, JobConsumerManager, EventAdmin) - Constructor for class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Start this queue
AbstractJobStatistics - Class in org.apache.sling.event.impl.jobs.jmx
 
AbstractJobStatistics() - Constructor for class org.apache.sling.event.impl.jobs.jmx.AbstractJobStatistics
 
AbstractParallelJobQueue - Class in org.apache.sling.event.impl.jobs.queues
Abstract base class for a parallel processing job queue.
AbstractParallelJobQueue(String, InternalQueueConfiguration, JobConsumerManager, EventAdmin, Scheduler) - Constructor for class org.apache.sling.event.impl.jobs.queues.AbstractParallelJobQueue
 
acknowledgeJob(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.acknowledgeJob(Event)
acknowledgeJob(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated. - Use the new JobConsumer interface instead.
activate(Map<String, Object>) - Method in class org.apache.sling.event.impl.dea.DistributedEventAdminConfiguration
 
activate() - Method in class org.apache.sling.event.impl.dea.DistributedEventReceiver
 
activate() - Method in class org.apache.sling.event.impl.dea.DistributedEventSender
 
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.MainQueueConfiguration
Activate this component.
activate(BundleContext) - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
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(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(StatisticsImpl) - Method in class org.apache.sling.event.impl.jobs.stats.StatisticsImpl
Add another statistics information.
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(JobImpl) - Method in class org.apache.sling.event.impl.jobs.BackgroundLoader
Add a job to the load job queue if the instance is running.
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, 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
Add a new job If the topic is null or illegal, no job is created and null is returned.
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.

B

BackgroundLoader - Class in org.apache.sling.event.impl.jobs
Task for loading stored jobs from the resource tree.
BackgroundLoader(JobManagerImpl, JobManagerConfiguration, ResourceResolverFactory) - Constructor for class org.apache.sling.event.impl.jobs.BackgroundLoader
Create and activate the loader.
bindJobConsumer(ServiceReference) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Bind a new consumer
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.AbstractParallelJobQueue
 
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. Use JobStatusProvider.removeJob(String) instead.
cancelJob(String, String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated. Use JobStatusProvider.removeJob(String, String) instead.
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
Cancel this timed event.
checkForUnprocessedJobs() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Periodically check for started jobs without an acknowledge.
checkJobTopic(Object) - Static method in class org.apache.sling.event.impl.jobs.Utility
Check the job topic.
clear() - Method in class org.apache.sling.event.EventPropertiesMap
 
clear() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
clear() - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
clear() - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
clear() - Method in class org.apache.sling.event.impl.jobs.queues.TopicRoundRobinJobQueue
 
clear() - Method in interface org.apache.sling.event.jobs.Queue
Remove all outstanding jobs from the queue.
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.TopologyCapabilities.InstanceDescriptionComparator
 
compareTo(InternalQueueConfiguration) - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
CONFIG_PROPERTY_BACKGROUND_LOAD_DELAY - Static variable in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
The background loader waits this time of seconds after startup before loading events from the repository.
CONFIG_PROPERTY_REPOSITORY_PATH - Static variable in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
The path where all jobs are stored.
configuration - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Configuration.
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
 
containsValue(Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
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
Create a distributable event.

D

deactivate() - Method in class org.apache.sling.event.impl.dea.DistributedEventReceiver
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.dea.DistributedEventSender
Deactivate this component.
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.BackgroundLoader
Deactivate the loader.
deactivate() - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
Deactivate this component.
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.timed.TimedEventReceiver
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
Deactivate this component.
deactivate() - Method in class org.apache.sling.event.impl.jobs.TopologyCapabilities
 
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.JobManagerConfiguration
Default background load delay.
DEFAULT_DISABLE_DISTRIBUTION - Static variable in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
Default for disabling the distribution.
DEFAULT_MAX_PARALLEL - 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.JobManagerConfiguration
Default repository path.
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_TYPE - Static variable in class org.apache.sling.event.impl.jobs.config.ConfigurationConstants
 
detectTarget(String, Map<String, Object>, QueueConfigurationManager.QueueInfo) - Method in class org.apache.sling.event.impl.jobs.TopologyCapabilities
Detect the target instance.
disableDistribution() - Method in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
 
DistributedEventAdminConfiguration - Class in org.apache.sling.event.impl.dea
This service wraps the configuration of the distributed event admin.
DistributedEventAdminConfiguration() - Constructor for class org.apache.sling.event.impl.dea.DistributedEventAdminConfiguration
 
DistributedEventReceiver - Class in org.apache.sling.event.impl.dea
This is the distributed event receiver.
DistributedEventReceiver() - Constructor for class org.apache.sling.event.impl.dea.DistributedEventReceiver
 
DistributedEventSender - Class in org.apache.sling.event.impl.dea
This event handler distributes events across an application cluster.
DistributedEventSender() - Constructor for class org.apache.sling.event.impl.dea.DistributedEventSender
 
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
 
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
 
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
 
equals(Object) - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
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
 
EventPropertiesMap - Class in org.apache.sling.event
An implementation of a map that helps in dealing with properties of an OSGi event.
EventPropertiesMap(Event) - Constructor for class org.apache.sling.event.EventPropertiesMap
Construct a new map out of an event object.
EventPropertiesMap(Map<String, Object>) - Constructor for class org.apache.sling.event.EventPropertiesMap
Construct a new map out of another map.
EventPropertiesMap() - Constructor for class org.apache.sling.event.EventPropertiesMap
Construct a new map.
EventUtil - Class in org.apache.sling.event
The EventUtil class is an utility class for clustered environments.
EventUtil() - Constructor for class org.apache.sling.event.EventUtil
 
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.timed.TimedEventSender
 
executeJob(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Execute a job

F

failed() - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer.AsyncHandler
 
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.
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
Deprecated.  
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 either running or scheduled.
finished() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
finished(JobHandler) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
finishedJob(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated. Use {link JobUtil.finishedJob(Event)
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
Deprecated.  
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
 
getAllInstancesMap(TopologyView) - Static method in class org.apache.sling.event.impl.jobs.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
Deprecated. Use JobStatusProvider.queryAllJobs(String, Map...) instead.
getApplicationId(Event) - Static method in class org.apache.sling.event.EventUtil
Return the application id the event was created at.
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.JobManagerConfiguration
Get the resource path for all assigned jobs.
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.JobManagerConfiguration
 
getChangeCount() - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
 
getChangeCount() - Method in class org.apache.sling.event.impl.jobs.TopologyCapabilities
 
getCleanupPeriod() - Method in class org.apache.sling.event.impl.dea.DistributedEventAdminConfiguration
 
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.
getConsumer(String) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Get the consumer for the topic.
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.
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
Deprecated. Use JobStatusProvider.queryCurrentJobs(String, Map...) instead.
getCurrentJobs(String, Map<String, Object>...) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated. Use JobStatusProvider.queryCurrentJobs(String, Map...) instead.
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.TopologyCapabilities
 
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
 
getJobByName(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getJobByName(String) - Method in interface org.apache.sling.event.jobs.JobManager
 
getJobCreated(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated. - Use the new Job interface instead.
getJobPriority() - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
getJobPriority() - Method in interface org.apache.sling.event.jobs.Job
This property is set by the job handling to define the priority of this job execution.
getJobStatusNotifier() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobStatusNotifier.NotifierContext
 
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.JobManagerConfiguration
Get the resource path for all jobs assigned to the current instance
getLocksPath() - Method in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
Get the resource path for all locks
getMainConfiguration() - Method in class org.apache.sling.event.impl.jobs.config.MainQueueConfiguration
 
getMainQueueConfiguration() - Method in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager
 
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!
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 interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
getName() - Method in interface org.apache.sling.event.jobs.Job
Optional job name
getName() - Method in interface org.apache.sling.event.jobs.Queue
Get the queue name.
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
This just adds Statistics.getNumberOfActiveJobs() and Statistics.getNumberOfQueuedJobs()
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
 
getOwnRootPath() - Method in class org.apache.sling.event.impl.dea.DistributedEventAdminConfiguration
This is the root path for all events.
getOwnRootPathWithSlash() - Method in class org.apache.sling.event.impl.dea.DistributedEventAdminConfiguration
This is the root path for all events of this instance.
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.TopologyCapabilities
Return the potential targets (Sling IDs) sorted by ID
getPreviousVersionAnonPath() - Method in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
 
getPreviousVersionIdentifiedPath() - Method in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
 
getPriority() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getPriority() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the thread priority for the job thread.
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.
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 interface org.apache.sling.event.jobs.JobManager
Return a queue with a specific name (if running)
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 interface org.apache.sling.event.jobs.JobManager
Return an iterator for all available queues.
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
 
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.
getRetryDelayInMs() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getRetryDelayInMs() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the retry delay in ms
getRootPath() - Method in class org.apache.sling.event.impl.dea.DistributedEventAdminConfiguration
This is the root path for all events.
getRootPathWithSlash() - Method in class org.apache.sling.event.impl.dea.DistributedEventAdminConfiguration
This is the root path for all events.
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
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
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(String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated. Use JobStatusProvider.queryScheduledJobs(String, Map...) instead.
getScheduledJobs(String, Map<String, Object>...) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated. Use JobStatusProvider.queryScheduledJobs(String, Map...) instead.
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.
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(String) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
getState(String) - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
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.AbstractParallelJobQueue
 
getStateInfo() - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
getStateInfo() - Method in class org.apache.sling.event.impl.jobs.queues.TopicRoundRobinJobQueue
 
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.
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.
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 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 interface org.apache.sling.event.jobs.JobManager
Return statistics information about job topics.
getTopologyCapabilities() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
getType() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
getType() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the queue type.
getUnassignedJobsPath() - Method in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
Get the resource path for all unassigned jobs.
getUniqueId(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
Get the unique job id
getUniquePath(String, String, String, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.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

handleEvent(Event) - Method in class org.apache.sling.event.impl.dea.DistributedEventReceiver
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.dea.DistributedEventSender
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.console.WebConsolePlugin
 
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.timed.TimedEventReceiver
 
handleEvent(Event) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
handleTopologyEvent(TopologyEvent) - Method in class org.apache.sling.event.impl.dea.DistributedEventReceiver
 
handleTopologyEvent(TopologyEvent) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
handleTopologyEvent(TopologyEvent) - Method in class org.apache.sling.event.impl.jobs.timed.TimedEventSender
 
hashCode() - Method in class org.apache.sling.event.EventPropertiesMap
 
hashCode() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
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?

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
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.TopologyCapabilities
 
isActive(String) - Method in class org.apache.sling.event.impl.jobs.TopologyCapabilities
 
isBridgedEvent() - Method in class org.apache.sling.event.impl.jobs.JobImpl
Is this a bridged event?
isEmpty() - Method in class org.apache.sling.event.EventPropertiesMap
 
isEmpty() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Is the queue empty?
isEmpty() - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
isEmpty() - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
isEmpty() - Method in class org.apache.sling.event.impl.jobs.queues.TopicRoundRobinJobQueue
 
isJob(String) - Method in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
 
isJobEvent(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.isJobEvent(Event)
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
isLeader() - Method in class org.apache.sling.event.impl.jobs.TopologyCapabilities
Is the current instance the leader?
isLocal(Event) - Static method in class org.apache.sling.event.EventUtil
Is this a local event?
isLocalJob(String) - Method in class org.apache.sling.event.impl.jobs.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.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?
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.TopologyCapabilities
 
isSuspended() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
isSuspended() - Method in interface org.apache.sling.event.jobs.Queue
Is the queue currently suspended?
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)
isWaitingForNext - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Marker flag if the queue is waiting for another element (= empty)
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_ID - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. - Use the new Job interface instead.
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
 
jobCount - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractParallelJobQueue
 
JobHandler - Class in org.apache.sling.event.impl.jobs
This object adds actions to a JobImpl.
JobHandler(JobImpl, JobManagerImpl) - 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
Configuration of the job handling
JobManagerConfiguration(Map<String, Object>) - Constructor for class org.apache.sling.event.impl.jobs.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.
JobsIterator - Interface in org.apache.sling.event.jobs
Deprecated. - Use the new JobManager.findJobs(org.apache.sling.event.jobs.JobManager.QueryType, java.lang.String, long, java.util.Map...) methods instead.
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.  
JobUtil - Class in org.apache.sling.event.jobs
The Job class is an utility class for creating and processing jobs.
JobUtil.JobPriority - Enum in org.apache.sling.event.jobs
The priority for jobs.

K

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

L

loadJob(String) - Method in class org.apache.sling.event.impl.jobs.BackgroundLoader
Add a path to the load job queue if the instance is running.
logger - Variable in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
The logger.

M

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
 
MaintenanceTask - Class in org.apache.sling.event.impl.jobs
Maintenance task...
MaintenanceTask(JobManagerConfiguration, ResourceResolverFactory) - Constructor for class org.apache.sling.event.impl.jobs.MaintenanceTask
Constructor
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
 
modified(BundleContext, Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
 

N

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
Property containing the unique job ID.
NOTIFICATION_PROPERTY_JOB_NAME - Static variable in class org.apache.sling.event.jobs.JobUtil
Property containing the optional job name.
NOTIFICATION_PROPERTY_JOB_TOPIC - Static variable in class org.apache.sling.event.jobs.JobUtil
Property containing the job topic.
notifyFinished(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
notifyFinished(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractParallelJobQueue
 
notifyFinished(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
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, JobConsumerManager, EventAdmin) - 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.dea - package org.apache.sling.event.impl.dea
 
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.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.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, JobConsumerManager, EventAdmin, Scheduler) - Constructor for class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
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.deprecated.EventAdminBridge
 
process(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Add a new job to the queue.
process(Job) - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer
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
Deprecated. Use JobUtil.processJob(Event, org.apache.sling.event.jobs.JobProcessor)
processJob(Event, JobProcessor) - Static method in class org.apache.sling.event.jobs.JobUtil
Deprecated. - Use the new JobConsumer interface instead.
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_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_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
 
PROPERTY_APPLICATION - Static variable in class org.apache.sling.event.EventUtil
This event property specifies the application node.
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_DISABLE_DISTRIBUTION - Static variable in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
Configuration switch for distributing the jobs.
PROPERTY_DISTRIBUTE - Static variable in class org.apache.sling.event.EventUtil
This event property indicates, if the event should be distributed in the cluster (default false).
PROPERTY_EVENT_ID - Static variable in interface org.apache.sling.event.JobStatusProvider
Deprecated. Use JobUtil.JOB_ID
PROPERTY_EVENT_ID - Static variable in interface org.apache.sling.event.TimedEventStatusProvider
This is a unique identifier which can be used to cancel the job.
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_ID - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.PROPERTY_JOB_NAME
PROPERTY_JOB_NAME - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. - Jobs should be started via JobManager.addJob(String, String, java.util.Map)
PROPERTY_JOB_PARALLEL - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.PROPERTY_JOB_PARALLEL
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
Deprecated. Use JobUtil.PROPERTY_JOB_PRIORITY
PROPERTY_JOB_PRIORITY - Static variable in interface org.apache.sling.event.jobs.Job
This property is set by the job handling to define the priority of this job execution.
PROPERTY_JOB_PRIORITY - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. - Use the new Job interface instead.
PROPERTY_JOB_QUEUE_NAME - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.PROPERTY_JOB_QUEUE_NAME
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
Deprecated. Use JobUtil.PROPERTY_JOB_QUEUE_ORDERED
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
Deprecated. Use JobUtil.PROPERTY_JOB_RETRIES
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
Deprecated. Use JobUtil.PROPERTY_JOB_RETRY_COUNT
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
Deprecated. Use JobUtil.PROPERTY_JOB_RETRY_DELAY
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
Deprecated. Use JobUtil.PROPERTY_JOB_RUN_LOCAL
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_TOPIC - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.PROPERTY_JOB_TOPIC
PROPERTY_JOB_TOPIC - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. - Jobs should be started via JobManager.addJob(String, String, java.util.Map)
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
Deprecated. Use JobUtil.PROPERTY_NOTIFICATION_JOB
PROPERTY_NOTIFICATION_JOB - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated.  
PROPERTY_RESOURCE_PATH - Static variable in class org.apache.sling.event.impl.jobs.JobImpl
Internal job property containing the resource path.
PROPERTY_TIME - Static variable in class org.apache.sling.event.impl.jobs.Utility
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
The date for the timed event.
PROPERTY_TIMED_EVENT_ID - Static variable in class org.apache.sling.event.EventUtil
The property for the unique event id.
PROPERTY_TIMED_EVENT_PERIOD - Static variable in class org.apache.sling.event.EventUtil
The period in seconds for the timed event.
PROPERTY_TIMED_EVENT_SCHEDULE - Static variable in class org.apache.sling.event.EventUtil
The scheduler cron expression for the timed event.
PROPERTY_TIMED_EVENT_TOPIC - Static variable in class org.apache.sling.event.EventUtil
The real topic of the event.
PROPERTY_TOPICS - Static variable in class org.apache.sling.event.impl.jobs.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.
put(String, Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
put(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Put another job into the queue.
put(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
put(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
put(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.TopicRoundRobinJobQueue
 
putAll(Map<? extends String, ? extends Object>) - Method in class org.apache.sling.event.EventPropertiesMap
 

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
Deprecated.  
queryJobs(JobManager.QueryType, String, long, Map<String, Object>...) - Method in interface org.apache.sling.event.jobs.JobManager
Deprecated.  
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.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
 
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.
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

reassign() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
reassign(JobHandler) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
reassignJob(JobImpl, String) - Method in class org.apache.sling.event.impl.jobs.MaintenanceTask
Reassign a job to a different target
remove(Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
remove() - Method in class org.apache.sling.event.impl.jobs.deprecated.JobsIteratorImpl
Deprecated.  
remove() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
remove(JobImpl) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Remove the job.
removeAll() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
removeAll() - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
removeAll() - Method in interface org.apache.sling.event.jobs.Queue
Remove all outstanding jobs and delete them.
removeAllJobs() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Remove all events from the queue and return them.
removeAllJobs() - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
removeAllJobs() - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
removeAllJobs() - Method in class org.apache.sling.event.impl.jobs.queues.TopicRoundRobinJobQueue
 
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
Deprecated.  
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.
reschedule() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
reschedule(JobHandler) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Reschedule a job.
reschedule(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Reschedule a job.
reschedule(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractParallelJobQueue
 
reschedule(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
rescheduleJob(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.rescheduleJob(Event)
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.JobManagerImpl
 
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
 
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.BackgroundLoader
Restart if the instance is currently running.
restart() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
 
restart() - Method in interface org.apache.sling.event.jobs.JobManager
Restart the job manager.
resume() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
 
resume() - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
resume() - Method in interface org.apache.sling.event.jobs.Queue
Resume a suspended queue.
retry() - Method in class org.apache.sling.event.impl.jobs.JobImpl
Update the information for a retry
run() - Method in class org.apache.sling.event.impl.dea.DistributedEventReceiver
This method is invoked periodically.
run() - Method in class org.apache.sling.event.impl.jobs.BackgroundLoader
 
run() - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
This method is invoked periodically by the scheduler.
run(TopologyCapabilities, QueueConfigurationManager, long) - Method in class org.apache.sling.event.impl.jobs.MaintenanceTask
One maintenance run
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

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.Utility
Helper method for sending the notification events.
sendNotification(EventAdmin, String, Job, Long) - Static method in class org.apache.sling.event.impl.jobs.Utility
Helper method for sending the notification events.
setProperty(String, Object) - Method in class org.apache.sling.event.impl.jobs.JobImpl
 
shouldDistribute(Event) - Static method in class org.apache.sling.event.EventUtil
Should this event be distributed in the cluster?
size() - Method in class org.apache.sling.event.EventPropertiesMap
 
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.BackgroundLoader
Start the background loader process.
start() - Method in class org.apache.sling.event.impl.jobs.JobHandler
 
start(JobHandler) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Try to start the job
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(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.AbstractParallelJobQueue
 
start(JobHandler) - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
started - Variable in class org.apache.sling.event.impl.jobs.JobHandler
 
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
 
StatisticsMBean - Interface in org.apache.sling.event.jobs.jmx
 
stop() - Method in class org.apache.sling.event.impl.jobs.BackgroundLoader
Stop the background loader process.
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
 
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.queues.AbstractJobQueue
 
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).

T

take() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Get another job from the queue.
take() - Method in class org.apache.sling.event.impl.jobs.queues.OrderedJobQueue
 
take() - Method in class org.apache.sling.event.impl.jobs.queues.ParallelJobQueue
 
take() - Method in class org.apache.sling.event.impl.jobs.queues.TopicRoundRobinJobQueue
 
targetId - Variable in class org.apache.sling.event.impl.jobs.config.QueueConfigurationManager.QueueInfo
 
THREAD_POOL - Static variable in class org.apache.sling.event.impl.support.Environment
Global thread pool.
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
This service provides the current timed events status.
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. Use JobUtil.TOPIC_JOB
TOPIC_JOB - Static variable in class org.apache.sling.event.jobs.JobUtil
Deprecated. - Use the new JobManager.addJob(String, String, java.util.Map) method instead.
TOPIC_JOB_CANCELLED - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.TOPIC_JOB_CANCELLED
TOPIC_JOB_CANCELLED - Static variable in class org.apache.sling.event.jobs.JobUtil
A synchronous notification event when a job is cancelled.
TOPIC_JOB_FAILED - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.TOPIC_JOB_FAILED
TOPIC_JOB_FAILED - Static variable in class org.apache.sling.event.jobs.JobUtil
Asynchronous notification event when a job failed.
TOPIC_JOB_FINISHED - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.TOPIC_JOB_FINISHED
TOPIC_JOB_FINISHED - Static variable in class org.apache.sling.event.jobs.JobUtil
Asynchronous notification event when a job is finished.
TOPIC_JOB_STARTED - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.TOPIC_JOB_STARTED
TOPIC_JOB_STARTED - Static variable in class org.apache.sling.event.jobs.JobUtil
Asynchronous notification event when a job is started.
TOPIC_TIMED_EVENT - Static variable in class org.apache.sling.event.EventUtil
The topic for timed events.
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
 
TopicRoundRobinJobQueue - Class in org.apache.sling.event.impl.jobs.queues
This queue acts similar to the parallel job queue.
TopicRoundRobinJobQueue(String, InternalQueueConfiguration, JobConsumerManager, EventAdmin, Scheduler) - Constructor for class org.apache.sling.event.impl.jobs.queues.TopicRoundRobinJobQueue
 
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
The capabilities of a topology.
TopologyCapabilities(TopologyView, boolean) - Constructor for class org.apache.sling.event.impl.jobs.TopologyCapabilities
 
TopologyCapabilities.InstanceDescriptionComparator - Class in org.apache.sling.event.impl.jobs
 
TopologyCapabilities.InstanceDescriptionComparator(String) - Constructor for class org.apache.sling.event.impl.jobs.TopologyCapabilities.InstanceDescriptionComparator
 
toString() - Method in class org.apache.sling.event.EventPropertiesMap
 
toString(Event) - Static method in class org.apache.sling.event.EventUtil
Improved toString method for an Event.
toString() - Method in class org.apache.sling.event.impl.jobs.config.InternalQueueConfiguration
 
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
 
tryToClose() - Method in class org.apache.sling.event.impl.jobs.queues.AbstractJobQueue
Check if the queue can be closed
tryToReloadUnloadedJobs() - Method in class org.apache.sling.event.impl.jobs.BackgroundLoader
Try to reload unloaded jobs - this method is invoked if bundles have been added etc.

U

unbindJobConsumer(ServiceReference) - Method in class org.apache.sling.event.impl.jobs.JobConsumerManager
Unbind a consumer
unbindThreadPool(EventingThreadPool) - Method in class org.apache.sling.event.impl.EnvironmentComponent
 
update(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.config.MainQueueConfiguration
Configure this component.
update(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobManagerConfiguration
Update with a new configuration
update(Map<String, Object>) - Method in class org.apache.sling.event.impl.jobs.JobManagerImpl
Configure this component.
update(boolean) - Method in class org.apache.sling.event.impl.jobs.TopologyCapabilities
Update the configuration
updateQueueInfo(Queue) - Method in class org.apache.sling.event.impl.jobs.JobImpl
Update information about the queue.
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.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.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
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.
values() - Method in class org.apache.sling.event.EventPropertiesMap
 
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.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.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
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.

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.
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
 

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

Copyright © 2007-2013 The Apache Software Foundation. All Rights Reserved.