A C E G I J M N O P Q R S T U V
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AbstractChannelSubscriber - Class in org.jenkinsci.plugins.pubsub
-
Simple asynchronous
ChannelSubscriber
ExtensionPoint
for Jenkins. - AbstractChannelSubscriber() - Constructor for class org.jenkinsci.plugins.pubsub.AbstractChannelSubscriber
C
- ChannelPublisher - Interface in org.jenkinsci.plugins.pubsub
- ChannelSubscriber - Interface in org.jenkinsci.plugins.pubsub
- clone() - Method in class org.jenkinsci.plugins.pubsub.JobMessage
-
Clone this
Message
instance. - clone() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Clone this
Message
instance. - clone() - Method in class org.jenkinsci.plugins.pubsub.QueueTaskMessage
-
Clone this
Message
instance. - clone() - Method in class org.jenkinsci.plugins.pubsub.RunMessage
-
Clone this
Message
instance. - containsAll(Properties) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Does this message contain all of the properties supplied in the properties argument.
E
- enrich(Message) - Method in class org.jenkinsci.plugins.pubsub.MessageEnricher
-
Enrich the message with some additional data.
- EventFilter - Class in org.jenkinsci.plugins.pubsub
-
Event filter.
- EventProps - Interface in org.jenkinsci.plugins.pubsub
-
Pre-defined event property name enumerations.
- EventProps.Item - Enum in org.jenkinsci.plugins.pubsub
-
Pre-defined
EventProps.Item
event property names. - EventProps.Jenkins - Enum in org.jenkinsci.plugins.pubsub
-
Pre-defined Jenkins/core event property names.
- EventProps.Job - Enum in org.jenkinsci.plugins.pubsub
-
Pre-defined Job channel event property names.
- Events - Interface in org.jenkinsci.plugins.pubsub
-
Pre-defined event type name enumerations.
- Events.JobChannel - Enum in org.jenkinsci.plugins.pubsub
-
Pre-defined "job" channel events.
G
- get(Enum) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the named message property value (by enum).
- get(String) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the named message property value.
- getAccessControlled() - Method in class org.jenkinsci.plugins.pubsub.JobChannelMessage
-
Get the Jenkins
AccessControlled
object associated with this message. - getAccessControlled() - Method in class org.jenkinsci.plugins.pubsub.RunMessage
-
Get the Jenkins
AccessControlled
object associated with this message. - getAuthentication() - Method in class org.jenkinsci.plugins.pubsub.AbstractChannelSubscriber
-
Deprecated.Use
AbstractChannelSubscriber.getAuthentication2()
instead. - getAuthentication2() - Method in class org.jenkinsci.plugins.pubsub.AbstractChannelSubscriber
-
Get the
Authentication
used for listening for events on the channel. - getBus() - Static method in class org.jenkinsci.plugins.pubsub.PubsubBus
-
Get the installed
PubsubBus
implementation. - getChannelName() - Method in class org.jenkinsci.plugins.pubsub.AbstractChannelSubscriber
-
Get the name of the channel on which the subscriber will listen.
- getChannelName() - Method in class org.jenkinsci.plugins.pubsub.JobChannelMessage
- getChannelName() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the channel name for the message.
- getEventFilter() - Method in class org.jenkinsci.plugins.pubsub.AbstractChannelSubscriber
-
Get the event filter to be used for messages on the channel.
- getEventName() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the event name for the message.
- getEventUUID() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the event UUID for the message.
- getJenkinsInstanceId() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the Jenkins instance identity of the controller from which the event was published.
- getJenkinsInstanceUrl() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the Jenkins instance URL of the controller from which the event was published.
- getJob() - Method in class org.jenkinsci.plugins.pubsub.JobChannelMessage
-
Deprecated.Use #getJobChannelItem.
- getJobChannelItem() - Method in class org.jenkinsci.plugins.pubsub.JobChannelMessage
-
Get the Jenkins
Item
associated with this message. - getJobName() - Method in class org.jenkinsci.plugins.pubsub.JobChannelMessage
- getObjectId() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the Jenkins domain model object Id that this message instance is associated with.
- getObjectName() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the Jenkins domain model object name (full name) that this message instance is associated with.
- getObjectType() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the Jenkins domain model object type that this message instance is associated with.
- getQueueItem() - Method in class org.jenkinsci.plugins.pubsub.QueueTaskMessage
- getRequiredPermission() - Method in class org.jenkinsci.plugins.pubsub.JobChannelMessage
- getRun() - Method in class org.jenkinsci.plugins.pubsub.RunMessage
-
Get the Jenkins
Run
associated with this message. - getTimestamp() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the event timestamp for the message.
- getTimestampMillis() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Get the event timestamp for the message, as a long.
- GuavaPubsubBus - Class in org.jenkinsci.plugins.pubsub
-
Default
PubsubBus
implementation. - GuavaPubsubBus() - Constructor for class org.jenkinsci.plugins.pubsub.GuavaPubsubBus
I
- item_rename_after - org.jenkinsci.plugins.pubsub.EventProps.Item
-
Item (e.g.
- item_rename_before - org.jenkinsci.plugins.pubsub.EventProps.Item
-
Item (e.g.
J
- jenkins_channel - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
The event channel name on which the message was sent.
- jenkins_event - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
The event name.
- jenkins_event_timestamp - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
The millisecond timestamp for when the event happened.
- jenkins_event_uuid - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
The event UUID.
- jenkins_instance_id - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
The ID of the Jenkins instance that published the message.
- jenkins_instance_url - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
The URL of the Jenkins instance that published the message.
- jenkins_object_id - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
Jenkins domain object unique ID.
- jenkins_object_name - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
Jenkins domain object full name.
- jenkins_object_type - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
Jenkins domain object type.
- jenkins_object_url - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
Jenkins domain object URL.
- jenkins_org - org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
The Jenkins organization origin of the event.
- job_crud_created - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job created.
- job_crud_deleted - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job deleted.
- job_crud_renamed - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job renamed.
- job_crud_updated - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job updated.
- job_ismultibranch - org.jenkinsci.plugins.pubsub.EventProps.Job
-
Job is a multi-branch job.
- job_multibranch_indexing_result - org.jenkinsci.plugins.pubsub.EventProps.Job
-
Multi-branch job indexing result.
- job_multibranch_indexing_status - org.jenkinsci.plugins.pubsub.EventProps.Job
-
Multi-branch job indexing status.
- job_name - org.jenkinsci.plugins.pubsub.EventProps.Job
-
Job name.
- job_run_artifact_fingerprinting - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run artifact fingerprinting.
- job_run_commitId - org.jenkinsci.plugins.pubsub.EventProps.Job
-
Job run SCM commit Id, if relevant.
- job_run_ended - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run ended.
- job_run_paused - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run paused.
- job_run_queue_blocked - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run queue blocked.
- job_run_queue_buildable - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run queue buildable.
- job_run_queue_enter - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run queue entered.
- job_run_queue_left - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run queue left.
- job_run_queue_task_complete - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run queue task complete.
- job_run_queueId - org.jenkinsci.plugins.pubsub.EventProps.Job
-
Job run Queue Id.
- job_run_scm_checkout - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run SCM checkout.
- job_run_started - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run started.
- job_run_status - org.jenkinsci.plugins.pubsub.EventProps.Job
-
Job run status/result.
- job_run_unpaused - org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Job run unpaused.
- JobChannelMessage<T extends JobChannelMessage> - Class in org.jenkinsci.plugins.pubsub
- JobChannelMessage(Item) - Constructor for class org.jenkinsci.plugins.pubsub.JobChannelMessage
- JobMessage - Class in org.jenkinsci.plugins.pubsub
-
Basic Job channel event message.
- JobMessage() - Constructor for class org.jenkinsci.plugins.pubsub.JobMessage
- JobMessage(Item) - Constructor for class org.jenkinsci.plugins.pubsub.JobMessage
M
- Message<T extends Message> - Class in org.jenkinsci.plugins.pubsub
-
PubsubBus
message instance. - MessageEnricher - Class in org.jenkinsci.plugins.pubsub
-
Message enricher extension point.
- MessageEnricher() - Constructor for class org.jenkinsci.plugins.pubsub.MessageEnricher
- MessageException - Exception in org.jenkinsci.plugins.pubsub
-
Message exception.
- MessageException(String) - Constructor for exception org.jenkinsci.plugins.pubsub.MessageException
- MessageException(String, Throwable) - Constructor for exception org.jenkinsci.plugins.pubsub.MessageException
N
- NAME - Static variable in enum org.jenkinsci.plugins.pubsub.Events.JobChannel
-
The channel name.
O
- onCreated(Item) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncJobCRUDListener
- onDeleted(Item) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncJobCRUDListener
- onEnterBlocked(Queue.BlockedItem) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncQueueListener
- onEnterBuildable(Queue.BuildableItem) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncQueueListener
- onEnterWaiting(Queue.WaitingItem) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncQueueListener
- onFinalized(Run<?, ?>) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncRunListener
- onLeft(Queue.LeftItem) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncQueueListener
- onMessage(Message) - Method in interface org.jenkinsci.plugins.pubsub.ChannelSubscriber
-
Consume a message.
- onRenamed(Item, String, String) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncJobCRUDListener
- onStarted(Run<?, ?>, TaskListener) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncRunListener
- onUpdated(Item) - Method in class org.jenkinsci.plugins.pubsub.listeners.SyncJobCRUDListener
- org.jenkinsci.plugins.pubsub - package org.jenkinsci.plugins.pubsub
- org.jenkinsci.plugins.pubsub.listeners - package org.jenkinsci.plugins.pubsub.listeners
-
Jenkins Listener implementations.
P
- publish(Message) - Method in interface org.jenkinsci.plugins.pubsub.ChannelPublisher
-
Publish a message on the channel.
- publish(Message) - Method in class org.jenkinsci.plugins.pubsub.PubsubBus
-
Publish a message on a channel.
- publisher(String) - Method in class org.jenkinsci.plugins.pubsub.GuavaPubsubBus
- publisher(String) - Method in class org.jenkinsci.plugins.pubsub.PubsubBus
-
Get/create a new
ChannelPublisher
instance for the specified channel name. - PubsubBus - Class in org.jenkinsci.plugins.pubsub
-
Abstract Pub-sub bus.
- PubsubBus() - Constructor for class org.jenkinsci.plugins.pubsub.PubsubBus
Q
- QueueTaskMessage - Class in org.jenkinsci.plugins.pubsub
-
Queue task job channel event message.
- QueueTaskMessage() - Constructor for class org.jenkinsci.plugins.pubsub.QueueTaskMessage
- QueueTaskMessage(Queue.Item, Item) - Constructor for class org.jenkinsci.plugins.pubsub.QueueTaskMessage
R
- RunMessage - Class in org.jenkinsci.plugins.pubsub
- RunMessage() - Constructor for class org.jenkinsci.plugins.pubsub.RunMessage
-
Create a plain message instance.
- RunMessage(Run) - Constructor for class org.jenkinsci.plugins.pubsub.RunMessage
-
Create a message instance associated with a Jenkins
Run
.
S
- set(Enum, String) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Fluent property setter (by enum).
- set(String, String) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Fluent property setter.
- setChannelName(String) - Method in class org.jenkinsci.plugins.pubsub.JobChannelMessage
- setChannelName(String) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Set the channel name for the message.
- setEventName(Enum) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Set the event name for the message.
- setEventName(String) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Set the event name for the message.
- setItemProps(Item) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Set
Item
propertis on the message instance. - setJenkinsInstanceId() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Set the Jenkins instance identity of the controller from which the event was published.
- shutdown() - Method in class org.jenkinsci.plugins.pubsub.GuavaPubsubBus
- shutdown() - Static method in class org.jenkinsci.plugins.pubsub.listeners.SyncQueueListener
- shutdown() - Method in class org.jenkinsci.plugins.pubsub.PubsubBus
-
Shutdown the bus.
- SimpleMessage - Class in org.jenkinsci.plugins.pubsub
-
A simple
Message
implementation. - SimpleMessage() - Constructor for class org.jenkinsci.plugins.pubsub.SimpleMessage
- start() - Method in class org.jenkinsci.plugins.pubsub.GuavaPubsubBus
- start() - Method in class org.jenkinsci.plugins.pubsub.PubsubBus
-
will start the bus if it has been shutdown do not restart if already started
- subscribe(String, ChannelSubscriber, Authentication, EventFilter) - Method in class org.jenkinsci.plugins.pubsub.PubsubBus
-
Deprecated.
- subscribe2(String, ChannelSubscriber, Authentication, EventFilter) - Method in class org.jenkinsci.plugins.pubsub.GuavaPubsubBus
- subscribe2(String, ChannelSubscriber, Authentication, EventFilter) - Method in class org.jenkinsci.plugins.pubsub.PubsubBus
-
Subscribe to events on the specified event channel.
- SyncJobCRUDListener - Class in org.jenkinsci.plugins.pubsub.listeners
-
Job CRUD event listener.
- SyncJobCRUDListener() - Constructor for class org.jenkinsci.plugins.pubsub.listeners.SyncJobCRUDListener
- SyncQueueListener - Class in org.jenkinsci.plugins.pubsub.listeners
-
Jenkins Queue event listener.
- SyncQueueListener() - Constructor for class org.jenkinsci.plugins.pubsub.listeners.SyncQueueListener
- SyncRunListener - Class in org.jenkinsci.plugins.pubsub.listeners
-
Jenkins Run event listener.
- SyncRunListener() - Constructor for class org.jenkinsci.plugins.pubsub.listeners.SyncRunListener
T
- toJSON() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Write the message properties to JSON.
- toJSON(Writer) - Method in class org.jenkinsci.plugins.pubsub.Message
-
Write the message properties as JSON to a
Writer
. - toString() - Method in class org.jenkinsci.plugins.pubsub.Message
-
Same as
Message.toJSON()
.
U
- unsubscribe(String, ChannelSubscriber) - Method in class org.jenkinsci.plugins.pubsub.GuavaPubsubBus
- unsubscribe(String, ChannelSubscriber) - Method in class org.jenkinsci.plugins.pubsub.PubsubBus
-
Unsubscribe from events on the specified event channel.
V
- valueOf(String) - Static method in enum org.jenkinsci.plugins.pubsub.EventProps.Item
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jenkinsci.plugins.pubsub.EventProps.Job
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.jenkinsci.plugins.pubsub.EventProps.Item
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.jenkinsci.plugins.pubsub.EventProps.Jenkins
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.jenkinsci.plugins.pubsub.EventProps.Job
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.jenkinsci.plugins.pubsub.Events.JobChannel
-
Returns an array containing the constants of this enum type, in the order they are declared.
All Classes All Packages