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

A

add() - Method in interface org.apache.sling.event.jobs.JobBuilder
Add the job.
add(List<String>) - Method in interface org.apache.sling.event.jobs.JobBuilder
Add the job.
add() - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Finally add the job to the schedule
add(List<String>) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Finally add the job to the schedule
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.
asyncProcessingFinished(JobExecutionResult) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Report an async result.
at(Date) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job for a specific date.

C

cancel() - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer.AsyncHandler
 
cancelled() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
The job processing failed permanently.
cancelled() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
If this returns true the job processing failed permanently.
createJob(String) - Method in interface org.apache.sling.event.jobs.JobManager
Fluent API to create, start and schedule new jobs
cron(String) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job for according to the cron expression.

D

daily(int, int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job daily at the given time.

F

failed() - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer.AsyncHandler
 
failed() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
The job processing failed and might be retried.
failed(long) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
The job processing failed and might be retried.
failed() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
If this returns true the job processing failed but might be retried..
findJobs(JobManager.QueryType, String, long, Map<String, Object>...) - Method in interface org.apache.sling.event.jobs.JobManager
Return all jobs of a given type.

G

getAt() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
Return the scheduled execution date for a schedule of type date.
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.
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 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.
getDayOfMonth() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
If the job is scheduled monthly, returns the day of the month
getDayOfWeek() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
If the job is scheduled weekly, returns the day of the week
getExpression() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
If the schedule is a cron expression, return the expression.
getFinishedDate() - Method in interface org.apache.sling.event.jobs.Job
If the job is cancelled or succeeded, this method will return the finish date.
getFinishedProgressStep() - Method in interface org.apache.sling.event.jobs.Job
If the job is in processing, return the optional information about the finished steps.
getHourOfDay() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
Return the hour of the day for daily and weekly scheduled jobs
getId() - Method in interface org.apache.sling.event.jobs.Job
Unique job ID.
getJob(String, Map<String, Object>) - Method in interface org.apache.sling.event.jobs.JobManager
Find a job - either queued or active.
getJobById(String) - Method in interface org.apache.sling.event.jobs.JobManager
Return a job based on the unique id.
getJobProperties() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Return the optional job topics.
getJobState() - Method in interface org.apache.sling.event.jobs.Job
Get the job state
getJobTopic() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Return the job topic.
getLastActivatedJobDate() - Method in interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
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 interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
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!
getMessage() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
Return the optional message.
getMinuteOfHour() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
Return the minute of the hour for daily, weekly and hourly scheduled jobs.
getMonthOfYear() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
If the job is scheduled yearly, returns the month of the year
getName() - Method in interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
getName() - Method in interface org.apache.sling.event.jobs.Queue
Get the queue name.
getNextScheduledExecution() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Return the next scheduled execution date.
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
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.
getNumberOfRetries() - Method in interface org.apache.sling.event.jobs.Job
The property to track the retry maximum retry count for jobs.
getOwnThreadPoolSize() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the size for the optional thread pool for this queue.
getProcessingStarted() - Method in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains a calendar object specifying the date and time when this job has been started.
getProgressETA() - Method in interface org.apache.sling.event.jobs.Job
If the job is in processing, return the optional ETA for this job.
getProgressLog() - Method in interface org.apache.sling.event.jobs.Job
This method returns the optional progress log from the last job processing.
getProgressStepCount() - Method in interface org.apache.sling.event.jobs.Job
If the job is in processing, return the optional progress step count if available.
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 interface org.apache.sling.event.jobs.Job
Get all property names.
getQueue(String) - Method in interface org.apache.sling.event.jobs.JobManager
Return a queue with a specific name (if running)
getQueueName() - Method in interface org.apache.sling.event.jobs.Job
The name of the job queue processing this job.
getQueueNames() - Method in interface org.apache.sling.event.jobs.jmx.QueuesMBean
 
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.
getResultMessage() - Method in interface org.apache.sling.event.jobs.Job
This method returns the message from the last job processing, regardless whether the processing failed, succeeded or was cancelled.
getRetryCount() - Method in interface org.apache.sling.event.jobs.Job
On first execution the value of this property is zero.
getRetryDelayInMs() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
Return the retry delay in ms
getRetryDelayInMs() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the retry delay in ms
getScheduledJobs() - Method in interface org.apache.sling.event.jobs.JobManager
Return all available job schedules.
getScheduledJobs(String, long, Map<String, Object>...) - Method in interface org.apache.sling.event.jobs.JobManager
Return all matching available job schedules.
getSchedules() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Get all schedules for this job
getStartDate() - Method in interface org.apache.sling.event.jobs.jmx.StatisticsMBean
 
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.
getTargetInstance() - Method in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains the Sling instance ID of the instance where this job should be processed.
getThreadPriority() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Return the thread priority for the job thread
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 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.
getType() - Method in interface org.apache.sling.event.jobs.ScheduleInfo
Return the scheduling type

H

hourly(int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job hourly at the given minute.

I

incrementProgressCount(int) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Update the progress by additionally marking the provided number of steps as finished.
initProgress(int, long) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Indicate that the job executor is able to report the progress.
isKeepJobs() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Whether successful jobs are kept for a complete history
isPreferRunOnCreationInstance() - Method in interface org.apache.sling.event.jobs.QueueConfiguration
Prefer to run the job on the same instance it was created on.
isStopped() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
If a job is stoppable, it should periodically check this method and stop processing if the method return true.
isSuspended() - Method in interface org.apache.sling.event.jobs.Queue
Is the queue currently suspended?
isSuspended() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Is the processing currently suspended?

J

Job - Interface in org.apache.sling.event.jobs
A job Property Types In general all scalar types and all serializable classes are supported as property types.
Job.JobState - Enum in org.apache.sling.event.jobs
The current job state.
JobBuilder - Interface in org.apache.sling.event.jobs
This is a builder interface to build jobs and scheduled jobs.
JobBuilder.ScheduleBuilder - Interface in org.apache.sling.event.jobs
This is a builder interface for creating schedule information
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
The result of the job processing.
JobExecutionContext - Interface in org.apache.sling.event.jobs.consumer
 
JobExecutionContext.ResultBuilder - Interface in org.apache.sling.event.jobs.consumer
 
JobExecutionResult - Interface in org.apache.sling.event.jobs.consumer
The status of a job after it has been processed by a JobExecutor.
JobExecutor - Interface in org.apache.sling.event.jobs.consumer
A job executor consumes a job.
JobManager - Interface in org.apache.sling.event.jobs
The job manager is the heart of the job processing.
JobManager.QueryType - Enum in org.apache.sling.event.jobs
The requested job types for the query.

L

log(String, Object...) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Log a message.

M

message(String) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
Add an optional processing message.
monthly(int, int, int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job monthly, the time needs to be specified in addition.

N

NOTIFICATION_PROPERTY_JOB_ID - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Property containing the unique job ID.
NOTIFICATION_PROPERTY_JOB_TOPIC - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Property containing the job topic.
NotificationConstants - Class in org.apache.sling.event.jobs
This class contains constants for event notifications.

O

ok() - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer.AsyncHandler
 
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
 

P

process(Job) - Method in interface org.apache.sling.event.jobs.consumer.JobConsumer
Execute the job.
process(Job, JobExecutionContext) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutor
Execute the job.
properties(Map<String, Object>) - Method in interface org.apache.sling.event.jobs.JobBuilder
Set the optional configuration properties for the job.
PROPERTY_FINISHED_DATE - Static variable in interface org.apache.sling.event.jobs.Job
This property contains the finished date once a job is marked as finished.
PROPERTY_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_INSTANCE - Static variable in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains the Sling instance ID of the instance where this job has been created.
PROPERTY_JOB_DESCRIPTION - Static variable in interface org.apache.sling.event.jobs.Job
This is an optional property containing a human readable description for the job
PROPERTY_JOB_PROGRESS_ETA - Static variable in interface org.apache.sling.event.jobs.Job
This property contains the optional ETA for a job.
PROPERTY_JOB_PROGRESS_LOG - Static variable in interface org.apache.sling.event.jobs.Job
This property contains the optional output log of a job consumer.
PROPERTY_JOB_PROGRESS_STEP - Static variable in interface org.apache.sling.event.jobs.Job
This property contains optional progress information about a job, the number of completed steps.
PROPERTY_JOB_PROGRESS_STEPS - Static variable in interface org.apache.sling.event.jobs.Job
This property contains optional progress information about a job, the number of steps the job consumer will perform.
PROPERTY_JOB_QUEUE_NAME - Static variable in interface org.apache.sling.event.jobs.Job
The name of the job queue processing this job.
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_RETRY_COUNT - Static variable in interface org.apache.sling.event.jobs.Job
The property to track the retry count for jobs.
PROPERTY_JOB_RETRY_DELAY - Static variable in interface org.apache.sling.event.jobs.Job
The property to set a retry delay.
PROPERTY_JOB_STARTED_TIME - Static variable in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains a calendar object specifying the date and time when this job has been started.
PROPERTY_JOB_TARGET_INSTANCE - Static variable in interface org.apache.sling.event.jobs.Job
This property is set by the job handling and contains the Sling instance ID of the instance where this job should be processed.
PROPERTY_JOB_TITLE - Static variable in interface org.apache.sling.event.jobs.Job
This is an optional property containing a human readable title for the job
PROPERTY_RESULT_MESSAGE - Static variable in interface org.apache.sling.event.jobs.Job
This property contains the optional result message of a job consumer.
PROPERTY_TOPICS - Static variable in interface org.apache.sling.event.jobs.consumer.JobConsumer
Service registration property defining the jobs this consumer is able to process.
PROPERTY_TOPICS - Static variable in interface org.apache.sling.event.jobs.consumer.JobExecutor
Service registration property defining the jobs this executor is able to process.

Q

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.ThreadPriority - Enum in org.apache.sling.event.jobs
The thread priority.
QueueConfiguration.Type - Enum in org.apache.sling.event.jobs
The queue type.
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.

R

removeAll() - Method in interface org.apache.sling.event.jobs.Queue
Remove all outstanding jobs and delete them.
removeJobById(String) - Method in interface org.apache.sling.event.jobs.JobManager
Removes the job even if it is currently in processing.
reschedule() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Reschedule this job with a new rescheduling information.
reset() - Method in interface org.apache.sling.event.jobs.Statistics
Clear all collected statistics and set the starting time to the current time.
result() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Build a result for the processing.
resume() - Method in interface org.apache.sling.event.jobs.Queue
Resume a suspended queue.
resume() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Resume job processing.
retryJobById(String) - Method in interface org.apache.sling.event.jobs.JobManager
Retry a cancelled job.

S

schedule() - Method in interface org.apache.sling.event.jobs.JobBuilder
Schedule the job
ScheduledJobInfo - Interface in org.apache.sling.event.jobs
Information about a scheduled job
ScheduleInfo - Interface in org.apache.sling.event.jobs
Scheduling information.
ScheduleInfo.ScheduleType - Enum in org.apache.sling.event.jobs
 
Statistics - Interface in org.apache.sling.event.jobs
Statistic information.
StatisticsMBean - Interface in org.apache.sling.event.jobs.jmx
 
stopJobById(String) - Method in interface org.apache.sling.event.jobs.JobManager
Stop a job.
succeeded() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext.ResultBuilder
The job processing finished successfully.
succeeded() - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionResult
If this returns true the job processing finished successfully.
suspend() - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Suspend this scheduling by default.
suspend() - Method in interface org.apache.sling.event.jobs.Queue
Suspend the queue - when a queue is suspended it stops processing jobs - however already started jobs are finished (but not rescheduled).
suspend() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Suspend this job scheduling.

T

TOPIC_JOB_ADDED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is added.
TOPIC_JOB_CANCELLED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is cancelled.
TOPIC_JOB_FAILED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job failed.
TOPIC_JOB_FINISHED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is finished.
TOPIC_JOB_REMOVED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is permanently removed.
TOPIC_JOB_STARTED - Static variable in class org.apache.sling.event.jobs.NotificationConstants
Asynchronous notification event when a job is started.
TopicStatistics - Interface in org.apache.sling.event.jobs
Statistic information about a topic.

U

unschedule() - Method in interface org.apache.sling.event.jobs.ScheduledJobInfo
Unschedule this scheduled job.
updateProgress(long) - Method in interface org.apache.sling.event.jobs.consumer.JobExecutionContext
Update the progress to the new ETA.

V

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

W

weekly(int, int, int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job weekly, the time needs to be specified in addition.

Y

yearly(int, int, int, int) - Method in interface org.apache.sling.event.jobs.JobBuilder.ScheduleBuilder
Schedule the job yearly, the time needs to be specified in addition.
A C D F G H I J L M N O P Q R S T U V W Y 

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