A C E F G H I J K O P Q R S T V W

A

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
Send an acknowledge.

C

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.
cancelTimedEvent(String) - Method in interface org.apache.sling.event.TimedEventStatusProvider
Cancel this timed event.
clear() - Method in class org.apache.sling.event.EventPropertiesMap
 
clear() - Method in interface org.apache.sling.event.jobs.Queue
Remove all outstanding jobs from the 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.
containsKey(Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
containsValue(Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
createDistributableEvent(String, Dictionary<String, Object>) - Static method in class org.apache.sling.event.EventUtil
Create a distributable event.

E

elements() - Method in class org.apache.sling.event.EventPropertiesMap
 
entrySet() - Method in class org.apache.sling.event.EventPropertiesMap
 
equals(Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
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

F

findJob(String, Map<String, Object>) - Method in interface org.apache.sling.event.jobs.JobManager
Find a job - either scheduled or active.
finishedJob(Event) - Static method in class org.apache.sling.event.EventUtil
Deprecated. Use {link JobUtil.finishedJob(Event)
finishedJob(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Notify a finished job.
forceRemoveJob(String) - Method in interface org.apache.sling.event.jobs.JobManager
Cancel this job.
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.

G

get(Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
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 interface org.apache.sling.event.jobs.QueueConfiguration
Application ids - returns an array of application ids if this queue is bound to some cluster nodes.
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 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.
getConfiguration() - Method in interface org.apache.sling.event.jobs.Queue
Get the corresponding configuration.
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.
getJobCreated(Event) - Static method in class org.apache.sling.event.jobs.JobUtil
Get the created calendar object.
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.
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.
getMaxParallel() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the max number of parallel processes.
getMaxRetries() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the max number of retries, -1 for endless retry!
getName() - Method in interface org.apache.sling.event.jobs.Queue
Get the queue name.
getNumberOfActiveJobs() - Method in interface org.apache.sling.event.jobs.Statistics
Number of jobs currently in processing.
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 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 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 interface org.apache.sling.event.jobs.Statistics
This just adds Statistics.getNumberOfActiveJobs() and Statistics.getNumberOfQueuedJobs()
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 interface org.apache.sling.event.jobs.Statistics
Number of jobs currently waiting in a queue.
getPosition() - Method in interface org.apache.sling.event.jobs.JobsIterator
Returns the current position within the iterator.
getPriority() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the thread priority for the job thread.
getQueue(String) - Method in interface org.apache.sling.event.jobs.JobManager
Return a queue with a specific name (if running)
getQueues() - Method in interface org.apache.sling.event.jobs.JobManager
Return an iterator for all available queues.
getRanking() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Get the ranking of this configuration.
getRetryDelayInMs() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the retry delay in ms
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 interface org.apache.sling.event.TimedEventStatusProvider
Return a list of currently schedulded events.
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 interface org.apache.sling.event.jobs.JobsIterator
Returns the total number of jobs.
getStartTime() - Method in interface org.apache.sling.event.jobs.Statistics
The time this service has been started
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 interface org.apache.sling.event.jobs.Queue
Return some information about the current state of the queue.
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.
getTopic() - Method in interface org.apache.sling.event.jobs.TopicStatistics
The topic this statistics is about.
getTopics() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
The list of topics this queue is bound to.
getTopicStatistics() - Method in interface org.apache.sling.event.jobs.JobManager
Return statistics information about job topics.
getType() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the queue type.

H

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

I

isEmpty() - Method in class org.apache.sling.event.EventPropertiesMap
 
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
Is this a job event?
isJobProcessingEnabled() - Method in interface org.apache.sling.event.jobs.JobManager
Is job processing enabled?
isLocal(Event) - Static method in class org.apache.sling.event.EventUtil
Is this a local event?
isLocalQueue() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Is this a local running queue (= processing only jobs started on the same instance.)
isSuspended() - Method in interface org.apache.sling.event.jobs.Queue
Is the queue currently suspended?

J

JOB_ID - Static variable in class org.apache.sling.event.jobs.JobUtil
This is a unique identifer which can be used to cancel the job.
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.
JobProcessor - Interface in org.apache.sling.event
Deprecated. Use org.apache.sling.event.jobs.JobProcessor
JobProcessor - Interface in org.apache.sling.event.jobs
A job processor processes a job in the background.
JobsIterator - Interface in org.apache.sling.event.jobs
This Iterator allows to iterate over Events.
JobsIterator - Interface in org.apache.sling.event
Deprecated.  
JobStatusProvider - Interface in org.apache.sling.event
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
 

O

org.apache.sling.event - package org.apache.sling.event
 
org.apache.sling.event.jobs - package org.apache.sling.event.jobs
 

P

process(Event) - Method in interface org.apache.sling.event.jobs.JobProcessor
Execute the job.
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
Process a job in the background and notify its success.
PROPERTY_APPLICATION - Static variable in class org.apache.sling.event.EventUtil
This event property specifies the application node.
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 identifer which can be used to cancel the job.
PROPERTY_JOB_CREATED - Static variable in class org.apache.sling.event.jobs.JobUtil
This property is set by the eventing and contains a calendar object specifying the date and time when 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
The property for the unique event name.
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
The property to set if a job can be run parallel to any other job.
PROPERTY_JOB_PRIORITY - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.PROPERTY_JOB_PRIORITY
PROPERTY_JOB_PRIORITY - Static variable in class org.apache.sling.event.jobs.JobUtil
This property allows to override the priority for the thread used to start this job.
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 class org.apache.sling.event.jobs.JobUtil
The property to set to put the jobs into a separate job queue.
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
If this property is set with any value, the queue processes the jobs in the same order as they have arrived.
PROPERTY_JOB_RETRIES - Static variable in class org.apache.sling.event.EventUtil
Deprecated. Use JobUtil.PROPERTY_JOB_RETRIES
PROPERTY_JOB_RETRIES - Static variable in class org.apache.sling.event.jobs.JobUtil
The property for setting the maximum number of retries.
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 class org.apache.sling.event.jobs.JobUtil
The property to track the retry count for jobs.
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 class org.apache.sling.event.jobs.JobUtil
The property to set a retry delay.
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
The property to set if a job should only be run on the same app it has been created.
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
The job topic property.
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
Property containing the job event.
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 for the timed event.
PROPERTY_TIMED_EVENT_SCHEDULE - Static variable in class org.apache.sling.event.EventUtil
The scheduler expression for the timed event.
PROPERTY_TIMED_EVENT_TOPIC - Static variable in class org.apache.sling.event.EventUtil
The real topic of the event.
put(String, Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
putAll(Map<? extends String, ? extends Object>) - Method in class org.apache.sling.event.EventPropertiesMap
 

Q

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 interface org.apache.sling.event.JobStatusProvider
Deprecated. Return the jobs which are currently in processing.
queryJobs(JobManager.QueryType, String, Map<String, Object>...) - Method in interface org.apache.sling.event.jobs.JobManager
Return all jobs either running or scheduled.
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 - Interface in org.apache.sling.event.jobs
The configuration of a queue.
QueueConfiguration.Type - Enum in org.apache.sling.event.jobs
The queue type.

R

remove(Object) - Method in class org.apache.sling.event.EventPropertiesMap
 
removeAll() - Method in interface org.apache.sling.event.jobs.Queue
Remove all outstanding jobs and delete them.
removeJob(String) - Method in interface org.apache.sling.event.jobs.JobManager
Cancel this job.
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.
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
Notify a failed job.
reset() - Method in interface org.apache.sling.event.jobs.Statistics
Clear all collected statistics and set the starting time to the current time.
restart() - Method in interface org.apache.sling.event.jobs.JobManager
Restart the job manager.
resume() - Method in interface org.apache.sling.event.jobs.Queue
Resume a suspended queue.

S

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 interface org.apache.sling.event.jobs.JobsIterator
Skip a number of jobs.
Statistics - Interface in org.apache.sling.event.jobs
Statistic information.
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

TimedEventStatusProvider - Interface in org.apache.sling.event
This service provides the current timed events status.
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
The topic for jobs.
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
Asynchronous 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.
TopicStatistics - Interface in org.apache.sling.event.jobs
Statistic information about a topic.
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.

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.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're 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're 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're 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're declared.

W

wakeUpJobQueue(String) - Method in interface org.apache.sling.event.JobStatusProvider
Deprecated. Wake up the named job queue.

A C E F G H I J K O P Q R S T V W

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