Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abandon(TaskInformation, Exception) - Method in interface com.github.workerframework.api.WorkerCallback
-
Indicates the Worker wishes to abandon this task, but return it to the queue so that it can be retried by this or another Worker instance.
- abort() - Method in class com.github.workerframework.core.JobStatusCacheRequest
- abortTasks() - Method in interface com.github.workerframework.api.TaskCallback
-
Signal that any tasks queued or in operation should be aborted.
- AbstractWorker<T,
V> - Class in com.github.workerframework.caf -
A partial Worker implementation with utility methods.
- AbstractWorker(T, String, Codec, WorkerTaskData) - Constructor for class com.github.workerframework.caf.AbstractWorker
-
Create a Worker.
- AbstractWorkerFactory<C,
T> - Class in com.github.workerframework.caf -
A WorkerFactory that uses a pre-defined configuration and Worker task class.
- AbstractWorkerFactory(ConfigurationSource, DataStore, Codec, Class<C>, Class<T>) - Constructor for class com.github.workerframework.caf.AbstractWorkerFactory
-
Instantiates a new DefaultWorkerFactory.
- acknowledgeTask(TaskInformation) - Method in interface com.github.workerframework.api.WorkerQueue
-
Called from the asynchronous worker service to notify the queue that it is acknowledging a task.
- acknowledgeTask(TaskInformation) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Called from the asynchronous worker service to notify the queue that it is acknowledging a task.
- acquire(DataSource) - Method in class com.github.cafapi.common.util.ref.ReferencedData
-
Return the referenced data as a stream, potentially performing a remote lookup.
- acquire(DataSource) - Method in class com.github.cafapi.common.util.ref.ReferencedObject
-
Return the referenced object, potentially performing a remote DataStore lookup and deserialisation.
- Active - Enum constant in enum class com.github.workerframework.api.JobStatus
- addResponse(WorkerResponse, boolean) - Method in interface com.github.workerframework.api.WorkerTaskData
-
Used when a task needs to return multiple responses.
- addTransientExceptionToRegistry(String) - Method in class com.github.workerframework.core.TransientHealthCheck
-
This method adds the supplied exceptionMsg text as a key to a Map and adds the time now as the corresponding value.
- areAllResponsesAcknowledged() - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
-
Check if all response have been acknowledged
- ask() - Method in class com.github.workerframework.util.rabbitmq.FutureEvent
- AUTO_REMOVE - Enum constant in enum class com.github.workerframework.util.rabbitmq.EmptyAction
-
Automatically remove this queue when it is empty.
B
- BootstrapConfiguration - Interface in com.github.cafapi.common.api
-
A bootstrap configuration is a method of providing basic, initial startup configuration.
- bootstrapLogging() - Method in class com.github.workerframework.core.WorkerApplication
- buildExceptionStackTrace(Throwable) - Method in class com.github.workerframework.caf.AbstractWorker
-
Builds up a stack trace with one level of cause stack trace
- BulkWorker - Interface in com.github.workerframework.api
-
This interface should be implemented by CAF Workers which are able to process multiple tasks together.
- BulkWorkerRuntime - Interface in com.github.workerframework.api
-
This object is supplied to CAF Workers which are able to process multiple tasks together.
C
- CafConfigurationDecoderProvider - Class in com.github.cafapi.common.config.decoder
-
Implements a default mechanism for selecting a Decoder to use when interpreting configuration files.
- CafConfigurationDecoderProvider() - Constructor for class com.github.cafapi.common.config.decoder.CafConfigurationDecoderProvider
- CafConfigurationSource - Class in com.github.cafapi.common.config.source
-
Partial implementation of a ManagedConfigurationSource that performs hierarchical lookups based upon the service's ServicePath, and recursive lookup for configuration objects that themselves have configuration in marked with the @Configuration annotation.
- CafConfigurationSource(BootstrapConfiguration, Cipher, ServicePath, Decoder) - Constructor for class com.github.cafapi.common.config.source.CafConfigurationSource
-
Each ConfigurationProvider itself takes some initial source of configuration which it may or may not use to initialise itself.
- call() - Method in class com.github.workerframework.datastores.fs.FileSystemDataStoreHealthcheck
- Cancelled - Enum constant in enum class com.github.workerframework.api.JobStatus
- checkIfInterrupted() - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method to check the interrupted flag of the current Thread and throw InterruptedException if true.
- Cipher - Interface in com.github.cafapi.common.api
-
Provides a method of encrypting and decrypting string data, such as passwords.
- CipherException - Exception in com.github.cafapi.common.api
-
Thrown when a Cipher encounters a failure when encrypting or decrypting information.
- CipherException(String, Throwable) - Constructor for exception com.github.cafapi.common.api.CipherException
-
Create a new CipherException.
- CipherProvider - Interface in com.github.cafapi.common.api
-
Simple boilerplate for returning a Cipher implementation.
- close() - Method in class com.github.cafapi.common.api.QuietResource
- Codec - Interface in com.github.cafapi.common.api
-
A Codec specifies methods to serialise data from a Java object to byte format, and deserialise data from byte format back into a specified Java class.
- CodecException - Exception in com.github.cafapi.common.api
-
Thrown when a Codec fails to encode or decode information.
- CodecException(String, Throwable) - Constructor for exception com.github.cafapi.common.api.CodecException
-
Create a new CodecException
- com.github.cafapi.common.api - package com.github.cafapi.common.api
- com.github.cafapi.common.bootstrapconfigs.system - package com.github.cafapi.common.bootstrapconfigs.system
- com.github.cafapi.common.ciphers.jasypt - package com.github.cafapi.common.ciphers.jasypt
- com.github.cafapi.common.ciphers.Null - package com.github.cafapi.common.ciphers.Null
- com.github.cafapi.common.codecs.json - package com.github.cafapi.common.codecs.json
- com.github.cafapi.common.codecs.jsonlzf - package com.github.cafapi.common.codecs.jsonlzf
- com.github.cafapi.common.config.decoder - package com.github.cafapi.common.config.decoder
- com.github.cafapi.common.config.source - package com.github.cafapi.common.config.source
- com.github.cafapi.common.config.sources.file - package com.github.cafapi.common.config.sources.file
- com.github.cafapi.common.decoders.js - package com.github.cafapi.common.decoders.js
- com.github.cafapi.common.elections.Null - package com.github.cafapi.common.elections.Null
- com.github.cafapi.common.util.jerseycompat - package com.github.cafapi.common.util.jerseycompat
- com.github.cafapi.common.util.moduleloader - package com.github.cafapi.common.util.moduleloader
- com.github.cafapi.common.util.naming - package com.github.cafapi.common.util.naming
- com.github.cafapi.common.util.processidentifier - package com.github.cafapi.common.util.processidentifier
- com.github.cafapi.common.util.ref - package com.github.cafapi.common.util.ref
- com.github.cafapi.common.util.secret - package com.github.cafapi.common.util.secret
- com.github.cafapi.common.util.tools - package com.github.cafapi.common.util.tools
- com.github.workerframework.api - package com.github.workerframework.api
- com.github.workerframework.caf - package com.github.workerframework.caf
- com.github.workerframework.configs - package com.github.workerframework.configs
- com.github.workerframework.core - package com.github.workerframework.core
- com.github.workerframework.datastores.fs - package com.github.workerframework.datastores.fs
- com.github.workerframework.datastores.http - package com.github.workerframework.datastores.http
- com.github.workerframework.datastores.mem - package com.github.workerframework.datastores.mem
- com.github.workerframework.datastores.s3 - package com.github.workerframework.datastores.s3
- com.github.workerframework.queues.rabbit - package com.github.workerframework.queues.rabbit
- com.github.workerframework.testworker - package com.github.workerframework.testworker
- com.github.workerframework.tracking.report - package com.github.workerframework.tracking.report
- com.github.workerframework.util.rabbitmq - package com.github.workerframework.util.rabbitmq
- complete(TaskInformation, String, TaskMessage) - Method in interface com.github.workerframework.api.WorkerCallback
-
Indicate a task was completed.
- Complete - Enum constant in enum class com.github.workerframework.tracking.report.TrackingReportStatus
-
Used to report the completion of a job task.
- Completed - Enum constant in enum class com.github.workerframework.api.JobStatus
- CONFIG_APP_NAME - Static variable in interface com.github.cafapi.common.api.BootstrapConfiguration
-
Application identifier configuration parameter key.
- CONFIG_PATH - Static variable in class com.github.cafapi.common.config.sources.file.FileConfigurationSource
- CONFIG_SECURITY_PASS - Static variable in class com.github.cafapi.common.ciphers.jasypt.JasyptCipher
-
The keyword used to encrypt and decrypt data.
- Configuration - Annotation Interface in com.github.cafapi.common.api
-
Indicates either that the class is a simple Java object that stores configuration, or for fields within a class, indicates this object is an embedded configuration object that can be overridden by a ConfigurationSource.
- ConfigurationDecoderProvider - Interface in com.github.cafapi.common.api
-
Simple interface to return the Decoder to use when reading the configuration files.
- ConfigurationException - Exception in com.github.cafapi.common.api
-
Indicates there was a problem in the ConfigurationSource module.
- ConfigurationException(String) - Constructor for exception com.github.cafapi.common.api.ConfigurationException
-
Create a new ConfigurationException
- ConfigurationException(String, Throwable) - Constructor for exception com.github.cafapi.common.api.ConfigurationException
-
Create a new ConfigurationException
- ConfigurationMetricsReporter - Interface in com.github.cafapi.common.api
-
Provides metrics for a ConfigurationSource.
- ConfigurationSource - Interface in com.github.cafapi.common.api
-
A ConfigurationSource is intended to provide an implementation-agnostic method of retrieving application-specific configuration.
- ConfigurationSourceProvider - Interface in com.github.cafapi.common.api
-
Simple boilerplate to return a ConfigurationSource.
- ConsumerAckEvent - Class in com.github.workerframework.util.rabbitmq
-
An acknowledge Event for a Consumer.
- ConsumerAckEvent(long) - Constructor for class com.github.workerframework.util.rabbitmq.ConsumerAckEvent
-
Create a new ConsumerAckEvent
- ConsumerDeliverEvent - Class in com.github.workerframework.util.rabbitmq
-
A deliver Event for a Consumer.
- ConsumerDeliverEvent(Delivery) - Constructor for class com.github.workerframework.util.rabbitmq.ConsumerDeliverEvent
-
Create aa new ConsumerDeliverEvent.
- ConsumerDropEvent - Class in com.github.workerframework.util.rabbitmq
-
A message drop Event for a Consumer.
- ConsumerDropEvent(long) - Constructor for class com.github.workerframework.util.rabbitmq.ConsumerDropEvent
-
Create a ConsumerDropEvent.
- ConsumerRejectEvent - Class in com.github.workerframework.util.rabbitmq
-
A message reject Event for a Consumer.
- ConsumerRejectEvent(long) - Constructor for class com.github.workerframework.util.rabbitmq.ConsumerRejectEvent
-
Create a new ConsumerRejectEvent.
- ContainsStringKeys - Annotation Interface in com.github.cafapi.common.api
-
Used on a field of type Map with String keys to indicate that they keys must contains specific Strings.
- ContainsStringKeysValidator - Class in com.github.cafapi.common.api
-
Validates a specific String key is present within a Map.
- ContainsStringKeysValidator() - Constructor for class com.github.cafapi.common.api.ContainsStringKeysValidator
- create(Channel) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
- createClassIterator(Class<T>, String, ClassLoader, boolean) - Method in class com.github.cafapi.common.util.jerseycompat.Jersey2ServiceIteratorProvider
-
Excludes all "com.sun.jersey" classes.
- createFailureResult(V) - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a WorkerReponse that represents a failed result.
- createFailureResult(V, byte[]) - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a WorkerReponse that represents a failed result with context data.
- createIterator(Class<T>, String, ClassLoader, boolean) - Method in class com.github.cafapi.common.util.jerseycompat.Jersey2ServiceIteratorProvider
- createRabbitConnection(RabbitConfiguration) - Static method in class com.github.workerframework.util.rabbitmq.RabbitUtil
-
Create a new RabbitMQ connection with custom settings.
- createRabbitConnection(RabbitConfiguration, ExceptionHandler) - Static method in class com.github.workerframework.util.rabbitmq.RabbitUtil
-
Create a new RabbitMQ connection with custom settings.
- createRabbitConnection(String, String, int, String, String) - Static method in class com.github.workerframework.util.rabbitmq.RabbitUtil
-
Create a new RabbitMQ connection with a default configuration.
- createSuccessAndCompleteResponse(V) - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a WorkerReponse that represents a successful result and reports complete.
- createSuccessNoOutputToQueue() - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a WorkerResponse that represents a success, but does not send a message to the worker's output message.
- createSuccessResult(V) - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a WorkerReponse that represents a successful result.
- createSuccessResult(V, byte[]) - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a WorkerReponse that represents a successful result with context data.
- createTaskCompleteResponse() - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a WorkerResponse that represents a success, but does not send a message to the worker's output message.
- createTaskSubmission(String, byte[], String, int) - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a new task submission to an arbitrary queue.
- createTaskSubmission(String, byte[], String, int, byte[]) - Method in class com.github.workerframework.caf.AbstractWorker
-
Utility method for creating a new task submission to an arbitrary queue with context data.
- createWorker(T, WorkerTaskData) - Method in class com.github.workerframework.caf.AbstractWorkerFactory
-
Create a Worker instance.
- createWorkerQueue(Channel) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
D
- DataSource - Class in com.github.cafapi.common.util.ref
-
Interface for defining how to retrieve objects or streams from a reference.
- DataSource() - Constructor for class com.github.cafapi.common.util.ref.DataSource
- DataSourceException - Exception in com.github.cafapi.common.util.ref
-
General exception for DataSource acquisition failures.
- DataSourceException(String) - Constructor for exception com.github.cafapi.common.util.ref.DataSourceException
- DataSourceException(String, Throwable) - Constructor for exception com.github.cafapi.common.util.ref.DataSourceException
- DataStore - Interface in com.github.workerframework.api
-
A representation of a generic data store, for reading and writing data typically used by workers in the course of their computation.
- DataStoreException - Exception in com.github.workerframework.api
-
Thrown by classes relevant to DataStore when it cannot handle a request.
- DataStoreException(String) - Constructor for exception com.github.workerframework.api.DataStoreException
- DataStoreException(String, Throwable) - Constructor for exception com.github.workerframework.api.DataStoreException
- DataStoreMetricsReporter - Interface in com.github.workerframework.api
-
Provides metrics for a DataStore.
- DataStoreOutputStreamSupport - Interface in com.github.workerframework.api
-
Supported by
DataStore
implementations which can supply an output stream for storing data. - DataStoreProvider - Interface in com.github.workerframework.api
-
Simple boilerplate to return a DataStore implementation.
- DataStoreSource - Class in com.github.workerframework.api
-
An implementation of a DataSource that uses a Worker DataStore and a CAF Codec.
- DataStoreSource(DataStore, Codec) - Constructor for class com.github.workerframework.api.DataStoreSource
-
Create a new DataStoreSource.
- declareQueue(Channel, String, Durability, Exclusivity, EmptyAction) - Static method in class com.github.workerframework.util.rabbitmq.RabbitUtil
-
Declare a queue with arbitrary parameters and default queue properties.
- declareQueue(Channel, String, Durability, Exclusivity, EmptyAction, Map<String, Object>) - Static method in class com.github.workerframework.util.rabbitmq.RabbitUtil
-
Declare a queue with arbitrary parameters and properties.
- declareWorkerQueue(Channel, String) - Static method in class com.github.workerframework.util.rabbitmq.RabbitUtil
-
Ensure a queue for a worker has been declared.
- declareWorkerQueue(Channel, String, int, String) - Static method in class com.github.workerframework.util.rabbitmq.RabbitUtil
-
Ensure a queue for a worker has been declared.
- DecodeMethod - Enum Class in com.github.cafapi.common.api
-
Dictates the decoding method for a Codec, specifying whether the Codec should perform strict decoding or be more lenient which can help in being tolerant to data from a subtly different class version of the object.
- Decoder - Interface in com.github.cafapi.common.api
-
A Decoder provides a facility to convert data to an object representation.
- decrypt(String) - Method in interface com.github.cafapi.common.api.Cipher
-
Decrypt a string.
- decrypt(String) - Method in class com.github.cafapi.common.ciphers.jasypt.JasyptCipher
- decrypt(String) - Method in class com.github.cafapi.common.ciphers.Null.NullCipher
- DEFAULT_READ_TIMEOUT_MILLIS - Static variable in class com.github.workerframework.datastores.http.HttpDataStoreConfiguration
- DefaultRabbitConsumer - Class in com.github.workerframework.util.rabbitmq
-
Default RabbitConsumer that uses QueueConsumer Event objects.
- DefaultRabbitConsumer(BlockingQueue<Event<QueueConsumer>>, QueueConsumer) - Constructor for class com.github.workerframework.util.rabbitmq.DefaultRabbitConsumer
-
Create a new DefaultRabbitConsumer.
- DefaultRabbitPublisher - Class in com.github.workerframework.util.rabbitmq
-
Default RabbitPublisher that uses QueuePublisher Event objects.
- DefaultRabbitPublisher(BlockingQueue<Event<QueuePublisher>>, QueuePublisher) - Constructor for class com.github.workerframework.util.rabbitmq.DefaultRabbitPublisher
-
Create a new DefaultRabbitPublisher
- delete(String) - Method in interface com.github.workerframework.api.DataStore
-
Delete asset identified by reference
- delete(String) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
-
Delete a file.
- delete(String) - Method in class com.github.workerframework.datastores.http.HttpDataStore
- delete(String) - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Remove the asset identified by the reference.
- delete(String) - Method in class com.github.workerframework.datastores.s3.S3DataStore
- Delivery - Class in com.github.workerframework.util.rabbitmq
-
Structure that contains data and metadata from a RabbitMQ queue delivery.
- Delivery(Envelope, byte[]) - Constructor for class com.github.workerframework.util.rabbitmq.Delivery
-
Create a new Delivery without headers.
- Delivery(Envelope, byte[], Map<String, Object>) - Constructor for class com.github.workerframework.util.rabbitmq.Delivery
-
Create a new Delivery, with specific headers.
- descendingPathIterator() - Method in class com.github.cafapi.common.util.naming.ServicePath
- DescendingPathIterator(Name) - Constructor for class com.github.cafapi.common.util.naming.ServicePath.DescendingPathIterator
- deserialise(byte[], Class<T>) - Method in interface com.github.cafapi.common.api.Codec
- deserialise(byte[], Class<T>, DecodeMethod) - Method in interface com.github.cafapi.common.api.Codec
-
Deserialise the given data into the specified class.
- deserialise(byte[], Class<T>, DecodeMethod) - Method in class com.github.cafapi.common.codecs.json.JsonCodec
- deserialise(byte[], Class<T>, DecodeMethod) - Method in class com.github.cafapi.common.codecs.jsonlzf.JsonLzfCodec
- deserialise(InputStream, Class<T>) - Method in interface com.github.cafapi.common.api.Codec
-
Deserialise the given data into the specified class using the default decode method.
- deserialise(InputStream, Class<T>) - Method in interface com.github.cafapi.common.api.Decoder
- deserialise(InputStream, Class<T>) - Method in class com.github.cafapi.common.decoders.js.JavascriptDecoder
- deserialise(InputStream, Class<T>, DecodeMethod) - Method in interface com.github.cafapi.common.api.Codec
-
Deserialise the given data into the specified class using the default decode method.
- deserialise(InputStream, Class<T>, DecodeMethod) - Method in class com.github.cafapi.common.codecs.json.JsonCodec
- deserialise(InputStream, Class<T>, DecodeMethod) - Method in class com.github.cafapi.common.codecs.jsonlzf.JsonLzfCodec
- determineForwardingAction(TaskMessage, TaskInformation, Map<String, Object>, WorkerCallback) - Method in interface com.github.workerframework.api.TaskMessageForwardingEvaluator
-
Deprecated.Examines the task message and decides whether to forward it or take some other action, e.g.
- discard(TaskInformation) - Method in interface com.github.workerframework.api.WorkerCallback
-
Indicates the Worker wishes to discard this task without returning it to the queue for retry.
- Discard - Enum constant in enum class com.github.workerframework.api.DivertedTaskAction
- discardTask(TaskInformation) - Method in interface com.github.workerframework.api.WorkerQueue
-
Called from the asynchronous worker service to notify the queue that it is discarding a task.
- discardTask(TaskInformation) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Called from the asynchronous worker service to notify the queue that it is discarding a task.
- disconnectIncoming() - Method in interface com.github.workerframework.api.ManagedWorkerQueue
-
Disconnects the incoming queue so that no more tasks are consumed.
- disconnectIncoming() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Disconnects the incoming queue so that no more tasks are consumed.
- DivertedTaskAction - Enum Class in com.github.workerframework.api
-
The action to be taken by a worker when it receives a message that has been diverted.
- DivertedTaskHandler - Interface in com.github.workerframework.api
-
A worker should implement this interface if it is capable of evaluating task messages that have been diverted (maybe because the worker's input queue is different from the target/to queue in the task message), and deciding what to do with them.
- doWork() - Method in interface com.github.workerframework.api.Worker
-
Start the work on a task.
- Durability - Enum Class in com.github.workerframework.util.rabbitmq
-
Possible states of durability for a RabbitMQ queue.
- DURABLE - Enum constant in enum class com.github.workerframework.util.rabbitmq.Durability
-
The queue contents are durable and should be disk backed.
E
- elected() - Method in interface com.github.cafapi.common.api.ElectionCallback
-
Indicates this instance has been elected.
- Election - Interface in com.github.cafapi.common.api
-
Allows interaction with the election process of an individual service election.
- ElectionCallback - Interface in com.github.cafapi.common.api
-
The endpoint that an election process will call to upon election or rejection of this instance from a particular Election.
- ElectionException - Exception in com.github.cafapi.common.api
-
Thrown if there is a problem with the election process.
- ElectionException(String, Throwable) - Constructor for exception com.github.cafapi.common.api.ElectionException
- ElectionFactory - Interface in com.github.cafapi.common.api
-
Factory class for returning Election objects for a specific service election.
- ElectionFactoryProvider - Interface in com.github.cafapi.common.api
-
Simple boilerplate for providing an ElectionFactory.
- EmptyAction - Enum Class in com.github.workerframework.util.rabbitmq
-
Possible actions to perform when a queue is empty for a RabbitMQ queue.
- encrypt(String) - Method in interface com.github.cafapi.common.api.Cipher
-
Encrypt a string.
- encrypt(String) - Method in class com.github.cafapi.common.ciphers.jasypt.JasyptCipher
- encrypt(String) - Method in class com.github.cafapi.common.ciphers.Null.NullCipher
- EncryptData - Class in com.github.cafapi.common.util.tools
-
Utility app for using a ServiceProvider to encrypt some data.
- Encrypted - Annotation Interface in com.github.cafapi.common.api
-
Marker annotation that specifies an item, typically in a configuration class, that a SecurityProvider can decrypt.
- enter() - Method in interface com.github.cafapi.common.api.Election
-
Request to enter the election process of this specific election
- enter() - Method in class com.github.cafapi.common.elections.Null.NullElection
- ENV_MARATHON_APP_ID - Static variable in class com.github.cafapi.common.bootstrapconfigs.system.SystemBootstrapConfiguration
- equals(Object) - Method in class com.github.cafapi.common.util.naming.Name
- estimatedPercentageCompleted - Variable in class com.github.workerframework.tracking.report.TrackingReport
-
The tracked job task's estimated percentage complete.
- Event<T> - Interface in com.github.workerframework.util.rabbitmq
-
A general event trigger with a target.
- EventPoller<T> - Class in com.github.workerframework.util.rabbitmq
-
An abstract class to poll a BlockingQueue for events and defer them for handling.
- EventPoller(int, BlockingQueue<Event<T>>, T) - Constructor for class com.github.workerframework.util.rabbitmq.EventPoller
-
Create a new EventPoller.
- EXCLUSIVE - Enum constant in enum class com.github.workerframework.util.rabbitmq.Exclusivity
-
The queue is exclusive to the channel consumer.
- Exclusivity - Enum Class in com.github.workerframework.util.rabbitmq
-
Possible states of exclusivity for a RabbitMQ queue.
- Execute - Enum constant in enum class com.github.workerframework.api.DivertedTaskAction
F
- Failed - Enum constant in enum class com.github.workerframework.api.JobStatus
- Failed - Enum constant in enum class com.github.workerframework.tracking.report.TrackingReportStatus
-
Used to report the failure and rejection of a job task.
- failure - Variable in class com.github.workerframework.tracking.report.TrackingReport
-
The failure details in the event of an invalid job task or exception.
- failureId - Variable in class com.github.workerframework.tracking.report.TrackingReportFailure
-
The failure id in the event of an invalid task or exception.
- failureMessage - Variable in class com.github.workerframework.tracking.report.TrackingReportFailure
-
The failure message in the event of an invalid task or exception.
- failureSource - Variable in class com.github.workerframework.tracking.report.TrackingReportFailure
-
The source of failure in the event of an invalid task or exception.
- failureTime - Variable in class com.github.workerframework.tracking.report.TrackingReportFailure
-
The time of failure in the event of an invalid task or exception.
- FileConfigurationSource - Class in com.github.cafapi.common.config.sources.file
-
This is a ConfigurationProvider that reads from a local disk file.
- FileConfigurationSource(BootstrapConfiguration, Cipher, ServicePath, Decoder) - Constructor for class com.github.cafapi.common.config.sources.file.FileConfigurationSource
- FileConfigurationSourceProvider - Class in com.github.cafapi.common.config.sources.file
- FileConfigurationSourceProvider() - Constructor for class com.github.cafapi.common.config.sources.file.FileConfigurationSourceProvider
- FileExtensions - Annotation Interface in com.github.cafapi.common.api
-
Used to associate a class with a file extension or a set of file extensions.
- FilePathProvider - Interface in com.github.workerframework.api
-
An interface intended to be implemented by DataStores that support the concept of a unique filepath to each stored asset.
- FileSystemDataStore - Class in com.github.workerframework.datastores.fs
-
This is a simple DataStore that reads and writes files to and from a directory upon the file system.
- FileSystemDataStore(FileSystemDataStoreConfiguration) - Constructor for class com.github.workerframework.datastores.fs.FileSystemDataStore
-
Determine the directory for the data store, and create it if necessary.
- FileSystemDataStoreConfiguration - Class in com.github.workerframework.datastores.fs
- FileSystemDataStoreConfiguration() - Constructor for class com.github.workerframework.datastores.fs.FileSystemDataStoreConfiguration
- FileSystemDataStoreHealthcheck - Class in com.github.workerframework.datastores.fs
- FileSystemDataStoreHealthcheck(Path) - Constructor for class com.github.workerframework.datastores.fs.FileSystemDataStoreHealthcheck
- FileSystemDataStoreProvider - Class in com.github.workerframework.datastores.fs
- FileSystemDataStoreProvider() - Constructor for class com.github.workerframework.datastores.fs.FileSystemDataStoreProvider
- forward(TaskInformation, String, TaskMessage, Map<String, Object>) - Method in interface com.github.workerframework.api.WorkerCallback
-
Indicates the Worker wishes to forward this task to the specified queue without processing it.
- Forward - Enum constant in enum class com.github.workerframework.api.DivertedTaskAction
- FutureEvent<T,
V> - Class in com.github.workerframework.util.rabbitmq -
A more complicated Event whereby a Future is obtainable in order to block/wait upon the result of it.
- FutureEvent() - Constructor for class com.github.workerframework.util.rabbitmq.FutureEvent
G
- GenerateConfig - Class in com.github.cafapi.common.util.tools
-
Utility app for generating configuration files.
- get() - Method in class com.github.cafapi.common.api.QuietResource
- get(URI) - Method in class com.github.workerframework.core.ResponseStreamCache
- get(URI, String, Map<String, List<String>>) - Method in class com.github.workerframework.core.JobStatusResponseCache
- getAccessKey() - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- getApiVersion() - Method in class com.github.workerframework.api.WorkerResponse
- getBackoffInterval() - Method in class com.github.workerframework.configs.RabbitConfiguration
- getBody() - Method in class com.github.workerframework.core.JobStatusCacheRequest
- getBody() - Method in class com.github.workerframework.core.JobStatusCacheResponse
- getBody() - Method in class com.github.workerframework.core.JobStatusSecureCacheResponse
- getBucketName() - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- getCipher() - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
- getCipher(BootstrapConfiguration) - Method in interface com.github.cafapi.common.api.CipherProvider
-
Get a Cipher implementation.
- getCipher(BootstrapConfiguration) - Method in class com.github.cafapi.common.ciphers.jasypt.JasyptCipherProvider
- getCipher(BootstrapConfiguration) - Method in class com.github.cafapi.common.ciphers.Null.NullCipherProvider
- getCipherSuite() - Method in class com.github.workerframework.core.JobStatusSecureCacheResponse
- getCipherSuite() - Method in class com.github.workerframework.core.ResponseStreamCache.SecureResponseStreamCacheEntry
- getClassifier() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves an indicator of the type of the task
- getCodec() - Method in class com.github.workerframework.caf.AbstractWorker
- getCodec() - Method in class com.github.workerframework.caf.AbstractWorkerFactory
- getConfiguration() - Method in class com.github.workerframework.caf.AbstractWorkerFactory
- getConfiguration(Class<T>) - Method in interface com.github.cafapi.common.api.ConfigurationSource
-
Acquire a configuration class.
- getConfiguration(Class<T>) - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
-
Acquire a configuration class from the provider.
- getConfiguration(String) - Method in interface com.github.cafapi.common.api.BootstrapConfiguration
-
Return the value of the requested configuration parameter.
- getConfiguration(String) - Method in class com.github.cafapi.common.bootstrapconfigs.system.SystemBootstrapConfiguration
- getConfigurationBoolean(String) - Method in interface com.github.cafapi.common.api.BootstrapConfiguration
-
Return the boolean representation of the requested configuration parameter.
- getConfigurationBoolean(String) - Method in class com.github.cafapi.common.bootstrapconfigs.system.SystemBootstrapConfiguration
- getConfigurationErrors() - Method in interface com.github.cafapi.common.api.ConfigurationMetricsReporter
- getConfigurationErrors() - Method in interface com.github.cafapi.common.api.ManagedConfigurationSource
- getConfigurationErrors() - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
- getConfigurationInteger(String) - Method in interface com.github.cafapi.common.api.BootstrapConfiguration
-
Return the integer representation of the requested configuration parameter.
- getConfigurationInteger(String) - Method in class com.github.cafapi.common.bootstrapconfigs.system.SystemBootstrapConfiguration
- getConfigurationInteger(String, int, int) - Method in interface com.github.cafapi.common.api.BootstrapConfiguration
-
Return the integer representation of the requested configuration parameter, between the minimum and maximum integers specified.
- getConfigurationInteger(String, int, int) - Method in class com.github.cafapi.common.bootstrapconfigs.system.SystemBootstrapConfiguration
- getConfigurationRequests() - Method in interface com.github.cafapi.common.api.ConfigurationMetricsReporter
- getConfigurationRequests() - Method in interface com.github.cafapi.common.api.ManagedConfigurationSource
- getConfigurationRequests() - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
- getConfigurationSource(BootstrapConfiguration, Cipher, ServicePath, Decoder) - Method in interface com.github.cafapi.common.api.ConfigurationSourceProvider
-
Acquire a ConfigurationSource implementation.
- getConfigurationSource(BootstrapConfiguration, Cipher, ServicePath, Decoder) - Method in class com.github.cafapi.common.config.sources.file.FileConfigurationSourceProvider
- getConfigurationStream(Class, Name) - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
-
Acquire and return a stream of the serialised data from the transport source.
- getConfigurationStream(Class, Name) - Method in class com.github.cafapi.common.config.sources.file.FileConfigurationSource
- getConnectTimeoutMillis() - Method in class com.github.workerframework.datastores.http.HttpDataStoreConfiguration
- getContext() - Method in class com.github.workerframework.api.TaskMessage
- getContext() - Method in class com.github.workerframework.api.WorkerResponse
- getContext() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves any task specific context associated with the task
- getCorrelationId() - Method in class com.github.workerframework.api.TaskMessage
- getCorrelationId() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves task specific correlationId
- getData() - Method in class com.github.cafapi.common.util.ref.ReferencedData
- getData() - Method in class com.github.workerframework.api.WorkerResponse
- getData() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves the actual task data in a serialised form
- getData() - Method in class com.github.workerframework.queues.rabbit.WorkerPublishQueueEvent
- getDataDir() - Method in class com.github.workerframework.datastores.fs.FileSystemDataStoreConfiguration
- getDataDirHealthcheckTimeoutSeconds() - Method in class com.github.workerframework.datastores.fs.FileSystemDataStoreConfiguration
- getDataSize(String) - Method in class com.github.cafapi.common.util.ref.DataSource
-
Determine the size of the data abstracted.
- getDataSize(String) - Method in class com.github.workerframework.api.DataStoreSource
- getDataStore() - Method in class com.github.workerframework.caf.AbstractWorkerFactory
- getDataStore(ConfigurationSource) - Method in interface com.github.workerframework.api.DataStoreProvider
- getDataStore(ConfigurationSource) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStoreProvider
- getDataStore(ConfigurationSource) - Method in class com.github.workerframework.datastores.http.HttpDataStoreProvider
- getDataStore(ConfigurationSource) - Method in class com.github.workerframework.datastores.mem.InMemoryDataStoreProvider
-
Return a InMemoryDataStore.
- getDataStore(ConfigurationSource) - Method in class com.github.workerframework.datastores.s3.S3DataStoreProvider
- getDecoder(BootstrapConfiguration, Decoder) - Method in interface com.github.cafapi.common.api.ConfigurationDecoderProvider
-
Returns the Decoder that should be used to interpret the configuration files.
- getDecoder(BootstrapConfiguration, Decoder) - Method in class com.github.cafapi.common.config.decoder.CafConfigurationDecoderProvider
-
Returns the Decoder that should be used to interpret the configuration files.
- getDefault() - Static method in enum class com.github.cafapi.common.api.DecodeMethod
- getDefaultJobStatusCheckIntervalMillis() - Static method in class com.github.workerframework.core.JobStatusResponseCache
- getDelaySeconds() - Method in class com.github.workerframework.testworker.TestWorkerTask
- getDeleteRequests() - Method in interface com.github.workerframework.api.DataStoreMetricsReporter
- getDeliverEvent(Envelope, byte[], Map<String, Object>) - Method in class com.github.workerframework.util.rabbitmq.DefaultRabbitConsumer
- getDeliverEvent(Envelope, byte[], Map<String, Object>) - Method in class com.github.workerframework.util.rabbitmq.RabbitConsumer
-
Get a new delivery event for internal handling of new messages
- getDelivery() - Method in class com.github.workerframework.util.rabbitmq.ConsumerDeliverEvent
- getElection(String, ElectionCallback) - Method in interface com.github.cafapi.common.api.ElectionFactory
-
Request a handle class used to interact with a particular service election.
- getElection(String, ElectionCallback) - Method in class com.github.cafapi.common.elections.Null.NullElectionFactory
- getElectionManager(ConfigurationSource) - Method in interface com.github.cafapi.common.api.ElectionFactoryProvider
-
Acquire a new ElectionFactory instance.
- getElectionManager(ConfigurationSource) - Method in class com.github.cafapi.common.elections.Null.NullElectionFactoryProvider
- getenv(String) - Static method in class com.github.cafapi.common.decoders.js.PropertyRetriever
-
Gets the value to use for the specified property.
- getEnvelope() - Method in class com.github.workerframework.util.rabbitmq.Delivery
- getErrors() - Method in interface com.github.workerframework.api.DataStoreMetricsReporter
- getEventQueue() - Method in class com.github.workerframework.util.rabbitmq.EventPoller
- getEventResult(T) - Method in class com.github.workerframework.util.rabbitmq.FutureEvent
-
Trigger the event and return a result.
- getExpiryTimeMillis() - Method in class com.github.workerframework.core.ResponseStreamCache.ResponseStreamCacheEntry
- getFilePath(String) - Method in interface com.github.workerframework.api.FilePathProvider
-
Obtains the unique path to the asset identified by the supplied storage reference.
- getFilePath(String) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
-
Obtains the unique path to the asset identified by the supplied storage reference.
- getGeneralFailureResult(Throwable) - Method in interface com.github.workerframework.api.Worker
-
In case of a Worker's doWork() method failing with an unhandled exception, it is expected a Worker should be able to return a general result.
- getGeneralFailureResult(Throwable) - Method in class com.github.workerframework.caf.AbstractWorker
- getGroup() - Method in class com.github.cafapi.common.util.naming.ServicePath
-
Return the immediate group of the service, ie.
- getHeaderMap() - Method in class com.github.workerframework.queues.rabbit.WorkerPublishQueueEvent
- getHeaders() - Method in class com.github.workerframework.core.JobStatusCacheResponse
- getHeaders() - Method in class com.github.workerframework.core.JobStatusSecureCacheResponse
- getHeaders() - Method in class com.github.workerframework.util.rabbitmq.Delivery
- getInboundMessageId() - Method in interface com.github.workerframework.api.TaskInformation
- getInboundMessageId() - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
- getIndex(int) - Method in class com.github.cafapi.common.util.naming.Name
-
Get the components of the Name at the specified numeric index
- getInputQueue() - Method in interface com.github.workerframework.api.WorkerQueue
-
Return the name of the input queue.
- getInputQueue() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Return the name of the input queue.
- getInputQueue() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- getInstance() - Static method in class com.github.cafapi.common.util.moduleloader.ModuleProvider
- getInvalidTaskQueue() - Method in interface com.github.workerframework.api.WorkerFactory
- getJobId() - Method in class com.github.workerframework.api.TrackingInfo
-
Extracts the job identifier from the tracking info's job task identifier.
- getJobTaskId() - Method in class com.github.workerframework.api.TrackingInfo
- getLastStatusCheckTime() - Method in class com.github.workerframework.api.TrackingInfo
- getLeaf() - Method in class com.github.cafapi.common.util.naming.ServicePath
-
Return the leaf or "tip" of the service path, ie.
- getLenientMapper() - Static method in class com.github.cafapi.common.codecs.json.ObjectMapperFactory
- getLenientMapper() - Static method in class com.github.cafapi.common.codecs.jsonlzf.ObjectMapperFactory
- getLivenessCheckIntervalSeconds() - Method in class com.github.workerframework.configs.HealthConfiguration
- getLivenessDowntimeIntervalSeconds() - Method in class com.github.workerframework.configs.HealthConfiguration
- getLivenessFailureAttempts() - Method in class com.github.workerframework.configs.HealthConfiguration
- getLivenessInitialDelaySeconds() - Method in class com.github.workerframework.configs.HealthConfiguration
- getLivenessSuccessAttempts() - Method in class com.github.workerframework.configs.HealthConfiguration
- getLocalCertificateChain() - Method in class com.github.workerframework.core.JobStatusSecureCacheResponse
- getLocalCertificateChain() - Method in class com.github.workerframework.core.ResponseStreamCache.SecureResponseStreamCacheEntry
- getLocalPrincipal() - Method in class com.github.workerframework.core.JobStatusSecureCacheResponse
- getLocalPrincipal() - Method in class com.github.workerframework.core.ResponseStreamCache.SecureResponseStreamCacheEntry
- getMapper(DecodeMethod) - Method in class com.github.cafapi.common.codecs.json.JsonCodec
- getMapper(DecodeMethod) - Method in class com.github.cafapi.common.codecs.jsonlzf.JsonLzfCodec
- getMaxAttempts() - Method in class com.github.workerframework.configs.RabbitConfiguration
- getMaxBackoffInterval() - Method in class com.github.workerframework.configs.RabbitConfiguration
- getMaxPriority() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- getMessage() - Method in class com.github.cafapi.common.api.HealthResult
- getMessageData() - Method in class com.github.workerframework.util.rabbitmq.Delivery
- getMessagesDropped() - Method in interface com.github.workerframework.api.WorkerQueueMetricsReporter
- getMessagesDropped() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- getMessagesPublished() - Method in interface com.github.workerframework.api.WorkerQueueMetricsReporter
- getMessagesPublished() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- getMessagesReceived() - Method in interface com.github.workerframework.api.WorkerQueueMetricsReporter
- getMessagesReceived() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- getMessagesRejected() - Method in interface com.github.workerframework.api.WorkerQueueMetricsReporter
- getMessagesRejected() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- getMessageType() - Method in class com.github.workerframework.api.WorkerResponse
- getMetrics() - Method in interface com.github.workerframework.api.ManagedDataStore
- getMetrics() - Method in interface com.github.workerframework.api.ManagedWorkerQueue
- getMetrics() - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
- getMetrics() - Method in class com.github.workerframework.datastores.http.HttpDataStore
- getMetrics() - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Get the Metrics for the in memory data store.
- getMetrics() - Method in class com.github.workerframework.datastores.s3.S3DataStore
- getMetrics() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
- getModule(Class<T>, String) - Method in class com.github.cafapi.common.util.moduleloader.ModuleProvider
-
Retrieves a module by its simple name, that implements a particular type T
- getName() - Method in class com.github.workerframework.api.TaskSourceInfo
- getNextWorkerTask() - Method in interface com.github.workerframework.api.BulkWorkerRuntime
-
Retrieves another task to be processed.
- getNextWorkerTask(long) - Method in interface com.github.workerframework.api.BulkWorkerRuntime
-
Retrieves another task to be processed.
- getObject(String, Class<T>) - Method in class com.github.cafapi.common.util.ref.DataSource
-
Retrieve an object of the specified class identified by a specific reference.
- getObject(String, Class<T>) - Method in class com.github.workerframework.api.DataStoreSource
- getOutputBufferSize() - Method in class com.github.workerframework.datastores.fs.FileSystemDataStoreConfiguration
- getPath() - Method in class com.github.cafapi.common.util.naming.ServicePath
- getPausedQueue() - Method in interface com.github.workerframework.api.WorkerQueue
-
Return the name of the paused queue.
- getPausedQueue() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Return the name of the paused queue.
- getPausedQueue() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- getPeerPrincipal() - Method in class com.github.workerframework.core.JobStatusSecureCacheResponse
- getPeerPrincipal() - Method in class com.github.workerframework.core.ResponseStreamCache.SecureResponseStreamCacheEntry
- getPoisonMessageResult(String) - Method in interface com.github.workerframework.api.Worker
-
If a message has been identified as a poison message, prepare a WorkerResponse that includes the friendly name of the worker.
- getPrefetchBuffer() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- getPrefix(int) - Method in class com.github.cafapi.common.util.naming.Name
-
Return a Name that consists of a subsection of the current Name.
- getPriority() - Method in class com.github.workerframework.api.TaskMessage
- getProcessId() - Static method in class com.github.cafapi.common.util.processidentifier.ProcessIdentifier
-
Returns a unique identifier for this process.
- getProxyHost() - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- getProxyPort() - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- getProxyProtocol() - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- getQueueErrors() - Method in interface com.github.workerframework.api.WorkerQueueMetricsReporter
- getQueueErrors() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- getQueueReference() - Method in class com.github.workerframework.api.WorkerResponse
- getQueueType() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- getRabbitConfiguration() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- getRabbitHost() - Method in class com.github.workerframework.configs.RabbitConfiguration
- getRabbitPassword() - Method in class com.github.workerframework.configs.RabbitConfiguration
- getRabbitPort() - Method in class com.github.workerframework.configs.RabbitConfiguration
- getRabbitProtocol() - Method in class com.github.workerframework.configs.RabbitConfiguration
- getRabbitUser() - Method in class com.github.workerframework.configs.RabbitConfiguration
- getReadinessCheckIntervalSeconds() - Method in class com.github.workerframework.configs.HealthConfiguration
- getReadinessDowntimeIntervalSeconds() - Method in class com.github.workerframework.configs.HealthConfiguration
- getReadinessFailureAttempts() - Method in class com.github.workerframework.configs.HealthConfiguration
- getReadinessInitialDelaySeconds() - Method in class com.github.workerframework.configs.HealthConfiguration
- getReadinessSuccessAttempts() - Method in class com.github.workerframework.configs.HealthConfiguration
- getReadTimeoutMillis() - Method in class com.github.workerframework.datastores.http.HttpDataStoreConfiguration
- getReference() - Method in class com.github.cafapi.common.util.ref.ReferencedData
- getReference() - Method in class com.github.cafapi.common.util.ref.ReferencedObject
- getReferencedData(String) - Static method in class com.github.cafapi.common.util.ref.ReferencedData
-
Create a ReferencedData object that uses a remote reference to data present in an ObjectSource.
- getReferencedObject(Class<T>, String) - Static method in class com.github.cafapi.common.util.ref.ReferencedObject
-
Create a ReferencedObject that uses a remote reference to data present in an ObjectSource.
- getRejectedQueue() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
-
Deprecated.
- getRejectQueue() - Method in class com.github.workerframework.api.WorkerConfiguration
- getResponseStream() - Method in class com.github.workerframework.core.ResponseStreamCache.ResponseStreamCacheEntry
- getResultQueue() - Method in class com.github.workerframework.caf.AbstractWorker
- getRetrieveRequests() - Method in interface com.github.workerframework.api.DataStoreMetricsReporter
- getRetryLimit() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- getRetryQueue() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- getRoot() - Method in class com.github.cafapi.common.util.naming.ServicePath
-
Return the root of the service path, ie.
- getRoutingKey() - Method in class com.github.workerframework.queues.rabbit.WorkerPublishQueueEvent
- getSecret(String) - Static method in class com.github.cafapi.common.decoders.js.SecretRetriever
-
Gets the value to use for the specified secret.
- getSecret(String) - Static method in class com.github.cafapi.common.util.secret.SecretUtil
-
Retrieves a secret value from various sources based on configuration: Environment variables (if CAF_ENABLE_ENV_SECRETS is true or not set) File content (if CAF_ENABLE_FILE_SECRETS is true and path specified by environment variable with "_FILE" suffix) For example, for a key "DATABASE_PASSWORD": First checks environment variable (if enabled): DATABASE_PASSWORD Then checks file path in environment variable (if enabled): DATABASE_PASSWORD_FILE
- getSecret(String, String) - Static method in class com.github.cafapi.common.util.secret.SecretUtil
-
Retrieves a secret value from various sources based on configuration: Environment variables (if CAF_ENABLE_ENV_SECRETS is true or not set) File content (if CAF_ENABLE_FILE_SECRETS is true and path specified by environment variable with "_FILE" suffix) For example, for a key "DATABASE_PASSWORD": First checks environment variable (if enabled): DATABASE_PASSWORD Then checks file path in environment variable (if enabled): DATABASE_PASSWORD_FILE
- getSecretKey() - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- getServerCertificateChain() - Method in class com.github.workerframework.core.JobStatusSecureCacheResponse
- getServerCertificateChain() - Method in class com.github.workerframework.core.ResponseStreamCache.SecureResponseStreamCacheEntry
- getService(Class<T>) - Static method in class com.github.cafapi.common.util.moduleloader.ModuleLoader
-
Determine the first advertised service implementation for the specified interface.
- getService(Class<T>, Class<? extends T>) - Static method in class com.github.cafapi.common.util.moduleloader.ModuleLoader
-
Determine the first advertised service implementation for the specified interface.
- getServiceOrElse(Class<T>, T) - Static method in class com.github.cafapi.common.util.moduleloader.ModuleLoader
-
Determine the first advertised service implementation for the specified interface.
- getServicePath() - Method in interface com.github.cafapi.common.api.BootstrapConfiguration
- getServicePath() - Method in class com.github.cafapi.common.bootstrapconfigs.system.SystemBootstrapConfiguration
- getServicePath() - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
- getServices(Class<T>) - Static method in class com.github.cafapi.common.util.moduleloader.ModuleLoader
-
Get all advertised service implementations of the specified interface.
- getSourceInfo() - Method in class com.github.workerframework.api.TaskMessage
- getSourceInfo() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves information relating to the source of the task
- getStatus() - Method in class com.github.cafapi.common.api.HealthResult
- getStatus() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves the task status
- getStatusCheckIntervalMillis() - Method in class com.github.workerframework.api.TrackingInfo
- getStatusCheckIntervalMillis(URLConnection) - Static method in class com.github.workerframework.core.JobStatusResponseCache
-
Extracts the job status check interval from the relevant response header on the connection.
- getStatusCheckUrl() - Method in class com.github.workerframework.api.TrackingInfo
- getStoreRequests() - Method in interface com.github.workerframework.api.DataStoreMetricsReporter
- getStream(String) - Method in class com.github.cafapi.common.util.ref.DataSource
-
Retrieve a stream of data identified by a specific reference.
- getStream(String) - Method in class com.github.workerframework.api.DataStoreSource
- getStrictMapper() - Static method in class com.github.cafapi.common.codecs.json.ObjectMapperFactory
- getStrictMapper() - Static method in class com.github.cafapi.common.codecs.jsonlzf.ObjectMapperFactory
- getTag() - Method in class com.github.workerframework.util.rabbitmq.ConsumerAckEvent
- getTag() - Method in class com.github.workerframework.util.rabbitmq.ConsumerDropEvent
- getTag() - Method in class com.github.workerframework.util.rabbitmq.ConsumerRejectEvent
- getTask() - Method in class com.github.workerframework.caf.AbstractWorker
- getTaskApiVersion() - Method in class com.github.workerframework.api.TaskMessage
- getTaskClassifier() - Method in class com.github.workerframework.api.TaskMessage
- getTaskData() - Method in class com.github.workerframework.api.TaskMessage
- getTaskId() - Method in class com.github.workerframework.api.TaskMessage
- getTaskInformation() - Method in class com.github.workerframework.queues.rabbit.WorkerPublishQueueEvent
- getTaskStatus() - Method in class com.github.workerframework.api.TaskMessage
- getTaskStatus() - Method in class com.github.workerframework.api.WorkerResponse
- getTo() - Method in class com.github.workerframework.api.TaskMessage
- getTo() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves the destination pipe to which the sender intends the task to be sent.
- getTracking() - Method in class com.github.workerframework.api.TaskMessage
- getTrackingInfo() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves tracking information associated with the task
- getTrackingPipe() - Method in class com.github.workerframework.api.TrackingInfo
- getTrackTo() - Method in class com.github.workerframework.api.TrackingInfo
- getTrackTo() - Method in class com.github.workerframework.api.WorkerResponse
- getUrl() - Method in class com.github.workerframework.datastores.http.HttpDataStoreConfiguration
- getValidator() - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
- getVersion() - Method in class com.github.workerframework.api.TaskMessage
- getVersion() - Method in class com.github.workerframework.api.TaskSourceInfo
- getVersion() - Method in interface com.github.workerframework.api.WorkerTaskData
-
Retrieves the version of the task message used
- getWorker(WorkerTaskData) - Method in interface com.github.workerframework.api.WorkerFactory
- getWorker(WorkerTaskData) - Method in class com.github.workerframework.caf.AbstractWorkerFactory
-
Verify that the incoming task has the right type and is a version that can be handled.
- getWorker(String, int, TaskStatus, byte[], byte[], TrackingInfo) - Method in interface com.github.workerframework.api.WorkerFactory
-
Instantiate a new worker for given task data
- getWorkerApiVersion() - Method in interface com.github.workerframework.api.Worker
-
This should return a number that identifies the API version that this worker uses, and should be incremented when the format of the task data (or result data) changes.
- getWorkerApiVersion() - Method in class com.github.workerframework.caf.AbstractWorkerFactory
- getWorkerConfiguration() - Method in interface com.github.workerframework.api.WorkerFactory
- getWorkerConfiguration() - Method in class com.github.workerframework.caf.AbstractWorkerFactory
- getWorkerFactory(ConfigurationSource, DataStore, Codec) - Method in interface com.github.workerframework.api.WorkerFactoryProvider
-
Generate a new worker given task data.
- getWorkerFactory(ConfigurationSource, DataStore, Codec) - Method in class com.github.workerframework.testworker.TestWorkerFactoryProvider
- getWorkerIdentifier() - Method in interface com.github.workerframework.api.Worker
- getWorkerName() - Method in class com.github.workerframework.api.WorkerConfiguration
- getWorkerName() - Method in class com.github.workerframework.caf.AbstractWorkerFactory
- getWorkerQueue(ConfigurationSource, int) - Method in interface com.github.workerframework.api.WorkerQueueProvider
-
Create a new WorkerQueue instance.
- getWorkerQueue(ConfigurationSource, int) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueProvider
- getWorkerTaskData() - Method in class com.github.workerframework.caf.AbstractWorker
- getWorkerThreads() - Method in interface com.github.workerframework.api.WorkerFactory
- getWorkerVersion() - Method in class com.github.workerframework.api.WorkerConfiguration
- getWrappedData(byte[]) - Static method in class com.github.cafapi.common.util.ref.ReferencedData
-
Create a ReferencedData instance that directly wraps data without a reference.
- getWrappedData(String, byte[]) - Static method in class com.github.cafapi.common.util.ref.ReferencedData
-
Create a ReferencedData instance that wraps data but also has a reference.
- getWrappedObject(Class<T>, T) - Static method in class com.github.cafapi.common.util.ref.ReferencedObject
-
Create a ReferencedObject that directly wraps an object without a reference.
- groupIterator() - Method in class com.github.cafapi.common.util.naming.ServicePath
- groups() - Element in annotation interface com.github.cafapi.common.api.ContainsStringKeys
H
- handleCancel(String) - Method in class com.github.workerframework.util.rabbitmq.RabbitConsumer
- handleCancelOk(String) - Method in class com.github.workerframework.util.rabbitmq.RabbitConsumer
- handleConsumeOk(String) - Method in class com.github.workerframework.util.rabbitmq.RabbitConsumer
- handleDelivery(String, Envelope, AMQP.BasicProperties, byte[]) - Method in class com.github.workerframework.util.rabbitmq.RabbitConsumer
- handleDivertedTask(TaskMessage, TaskInformation, Map<String, Object>, Codec, JobStatus, WorkerCallback) - Method in interface com.github.workerframework.api.DivertedTaskHandler
-
Examines the task message and decides what to do with it.
- handleEvent(WorkerPublisher) - Method in class com.github.workerframework.queues.rabbit.WorkerPublishQueueEvent
- handleEvent(QueueConsumer) - Method in class com.github.workerframework.util.rabbitmq.ConsumerAckEvent
-
Trigger the action represented by this Event.
- handleEvent(QueueConsumer) - Method in class com.github.workerframework.util.rabbitmq.ConsumerDeliverEvent
-
Trigger the action represented by this Event.
- handleEvent(QueueConsumer) - Method in class com.github.workerframework.util.rabbitmq.ConsumerDropEvent
-
Trigger the action represented by this Event.
- handleEvent(QueueConsumer) - Method in class com.github.workerframework.util.rabbitmq.ConsumerRejectEvent
-
Trigger the action represented by this Event.
- handleEvent(QueuePublisher) - Method in class com.github.workerframework.util.rabbitmq.PublisherPublishEvent
-
Trigger the action represented by this Event.
- handleEvent(T) - Method in interface com.github.workerframework.util.rabbitmq.Event
-
Trigger the action represented by this Event.
- handleEvent(T) - Method in class com.github.workerframework.util.rabbitmq.FutureEvent
-
Trigger the action represented by this Event.
- handlePublish(byte[]) - Method in interface com.github.workerframework.util.rabbitmq.QueuePublisher
-
Publish a new message
- handlePublish(byte[], String, RabbitTaskInformation, Map<String, Object>) - Method in interface com.github.workerframework.queues.rabbit.WorkerPublisher
-
Publish a new message to a specified queue and acknowledge a prior message by id.
- handlePublish(byte[], String, RabbitTaskInformation, Map<String, Object>) - Method in class com.github.workerframework.queues.rabbit.WorkerPublisherImpl
- handleRecoverOk(String) - Method in class com.github.workerframework.util.rabbitmq.RabbitConsumer
- handleRecovery(Recoverable) - Method in class com.github.workerframework.queues.rabbit.WorkerConnectionListener
- handleRecoveryStarted(Recoverable) - Method in class com.github.workerframework.queues.rabbit.WorkerConnectionListener
- handleShutdownSignal(String, ShutdownSignalException) - Method in class com.github.workerframework.util.rabbitmq.RabbitConsumer
- hashCode() - Method in class com.github.cafapi.common.util.naming.Name
- hasNext() - Method in class com.github.cafapi.common.util.naming.ServicePath.DescendingPathIterator
- healthCheck() - Method in interface com.github.cafapi.common.api.HealthReporter
- healthCheck() - Method in class com.github.cafapi.common.config.sources.file.FileConfigurationSource
- healthCheck() - Method in class com.github.workerframework.core.TransientHealthCheck
-
This method checks if any entry in the Transient Exception Registry is newer than the time now, minus the elapsed time interval.
- healthCheck() - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
- healthCheck() - Method in class com.github.workerframework.datastores.http.HttpDataStore
- healthCheck() - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Always return a RESULT_HEALTHY health check as the data store is in memory.
- healthCheck() - Method in class com.github.workerframework.datastores.s3.S3DataStore
- healthCheck() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
- HealthConfiguration - Class in com.github.workerframework.configs
-
Configuration for the liveness and readiness checks.
- HealthConfiguration() - Constructor for class com.github.workerframework.configs.HealthConfiguration
- HealthReporter - Interface in com.github.cafapi.common.api
-
Indicates this object can report on its health.
- HealthResult - Class in com.github.cafapi.common.api
-
A result returned from a class that implements HealthReporter, indicating its health status and if necessary, a message detailing further information.
- HealthResult(HealthStatus) - Constructor for class com.github.cafapi.common.api.HealthResult
- HealthResult(HealthStatus, String) - Constructor for class com.github.cafapi.common.api.HealthResult
- HealthStatus - Enum Class in com.github.cafapi.common.api
-
The overall, concise status of the health of a service.
- HEALTHY - Enum constant in enum class com.github.cafapi.common.api.HealthStatus
-
The service is healthy and operating normally.
- HttpDataStore - Class in com.github.workerframework.datastores.http
-
A
DataStore
that reads and writes files to and from a HTTP server. - HttpDataStore(HttpDataStoreConfiguration) - Constructor for class com.github.workerframework.datastores.http.HttpDataStore
- HttpDataStoreConfiguration - Class in com.github.workerframework.datastores.http
- HttpDataStoreConfiguration() - Constructor for class com.github.workerframework.datastores.http.HttpDataStoreConfiguration
- HttpDataStoreProvider - Class in com.github.workerframework.datastores.http
- HttpDataStoreProvider() - Constructor for class com.github.workerframework.datastores.http.HttpDataStoreProvider
I
- incremementErrors() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- incrementAcknowledgementCount() - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
-
Increment the count of acknowledgements.
- incrementDropped() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- incrementErrors() - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
-
Increase the number of configuration errors recorded.
- incrementPublished() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- incrementReceived() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- incrementRejected() - Method in class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- incrementRequests() - Method in class com.github.cafapi.common.config.source.CafConfigurationSource
-
Increase the number of configuration requests recorded.
- incrementResponseCount(boolean) - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
-
Increment the count of Responses.
- initialize(ContainsStringKeys) - Method in class com.github.cafapi.common.api.ContainsStringKeysValidator
- initialize(Bootstrap<WorkerConfiguration>) - Method in class com.github.workerframework.core.WorkerApplication
- InMemoryDataStore - Class in com.github.workerframework.datastores.mem
-
ManagedDataStore implementation for an In Memory Datastore which uses a HashMap.
- InMemoryDataStore() - Constructor for class com.github.workerframework.datastores.mem.InMemoryDataStore
- InMemoryDataStoreProvider - Class in com.github.workerframework.datastores.mem
- InMemoryDataStoreProvider() - Constructor for class com.github.workerframework.datastores.mem.InMemoryDataStoreProvider
- INVALID_TASK - Enum constant in enum class com.github.workerframework.api.TaskStatus
-
The task data failed validation or could not be understood.
- InvalidJobTaskIdException - Exception in com.github.workerframework.api
-
Indicates that a job task identifier, used in job tracking, has an invalid format.
- InvalidJobTaskIdException(String) - Constructor for exception com.github.workerframework.api.InvalidJobTaskIdException
- InvalidJobTaskIdException(String, Throwable) - Constructor for exception com.github.workerframework.api.InvalidJobTaskIdException
- InvalidTaskException - Exception in com.github.workerframework.api
-
Indicates this task is fundamentally flawed in some manner, and is likely an error situation that would not be resolved through retrying.
- InvalidTaskException(String) - Constructor for exception com.github.workerframework.api.InvalidTaskException
- InvalidTaskException(String, Throwable) - Constructor for exception com.github.workerframework.api.InvalidTaskException
- isAckEventSent() - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
-
Get the AckEventSent flag
- isConfigurationPresent(String) - Method in interface com.github.cafapi.common.api.BootstrapConfiguration
-
Determine if a configuration parameter has been set or not.
- isConfigurationPresent(String) - Method in class com.github.cafapi.common.bootstrapconfigs.system.SystemBootstrapConfiguration
- isNegativeAckEventSent() - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
-
Get the NegativeAckEventSent flag
- isPoison() - Method in interface com.github.workerframework.api.TaskInformation
- isPoison() - Method in interface com.github.workerframework.api.WorkerTask
-
Used by the Worker to determine that a message is poison and cannot be processed by the worker as it has failed and or crashed the worker on number of occasions previously
- isPoison() - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
-
Check if the message is poison
- isPoison() - Method in class com.github.workerframework.testworker.TestWorkerTask
- isResult(TaskStatus) - Static method in enum class com.github.workerframework.api.TaskStatus
-
Determine if this TaskStatus classifies as a result
- isSuccessfulResponse(TaskStatus) - Static method in enum class com.github.workerframework.api.TaskStatus
-
Determine if a TaskStatus classifies as a successful response
- isValid(Map<?, ?>, ConstraintValidatorContext) - Method in class com.github.cafapi.common.api.ContainsStringKeysValidator
- iterator() - Method in class com.github.cafapi.common.util.naming.Name
- iterator() - Method in class com.github.cafapi.common.util.naming.ServicePath
-
Each iteration is the next element of the service path.
J
- JasyptCipher - Class in com.github.cafapi.common.ciphers.jasypt
-
Implementation of a SecurityProvider that uses Jasypt to provide basic text encryption/decryption capabilities.
- JasyptCipher(BootstrapConfiguration) - Constructor for class com.github.cafapi.common.ciphers.jasypt.JasyptCipher
-
The cipher.pass variable must be present in the bootstrap configuration for this provider to init.
- JasyptCipherProvider - Class in com.github.cafapi.common.ciphers.jasypt
- JasyptCipherProvider() - Constructor for class com.github.cafapi.common.ciphers.jasypt.JasyptCipherProvider
- JavascriptDecoder - Class in com.github.cafapi.common.decoders.js
-
Decoder implementation that supports building objects from JavaScript.
- JavascriptDecoder() - Constructor for class com.github.cafapi.common.decoders.js.JavascriptDecoder
- Jersey2ServiceIteratorProvider - Class in com.github.cafapi.common.util.jerseycompat
-
Compatibility class to allow Jersey 1 libraries to co-exist with Jersey 2 apps, such as Dropwizard.
- Jersey2ServiceIteratorProvider() - Constructor for class com.github.cafapi.common.util.jerseycompat.Jersey2ServiceIteratorProvider
- JobNotFoundException - Exception in com.github.workerframework.api
-
Indicates that a job has not been found.
- JobNotFoundException(String) - Constructor for exception com.github.workerframework.api.JobNotFoundException
- JobNotFoundException(String, Throwable) - Constructor for exception com.github.workerframework.api.JobNotFoundException
- JobStatus - Enum Class in com.github.workerframework.api
-
Job status returned by the status check URL.
- JobStatusCacheRequest - Class in com.github.workerframework.core
-
An implementation of CacheRequest supporting the caching of job status requests.
- JobStatusCacheRequest(ResponseStreamCache, URI, URLConnection) - Constructor for class com.github.workerframework.core.JobStatusCacheRequest
- JobStatusCacheResponse - Class in com.github.workerframework.core
-
An implementation of CacheResponse supporting the caching of job status responses.
- JobStatusCacheResponse(ByteArrayOutputStream) - Constructor for class com.github.workerframework.core.JobStatusCacheResponse
- JobStatusResponseCache - Class in com.github.workerframework.core
-
An implementation of ResponseCache supporting the caching of job status responses.
- JobStatusResponseCache() - Constructor for class com.github.workerframework.core.JobStatusResponseCache
- JobStatusSecureCacheResponse - Class in com.github.workerframework.core
-
An implementation of SecureCacheResponse supporting the caching of job status responses.
- JobStatusSecureCacheResponse(ByteArrayOutputStream, String, List<Certificate>, List<Certificate>, Principal, Principal) - Constructor for class com.github.workerframework.core.JobStatusSecureCacheResponse
- jobTaskId - Variable in class com.github.workerframework.tracking.report.TrackingReport
-
The identifier of the tracked job task whose progress is being reported.
- JsonCodec - Class in com.github.cafapi.common.codecs.json
-
Implementation of Codec that supports serialisation and deserialisation to and form JSON format.
- JsonCodec() - Constructor for class com.github.cafapi.common.codecs.json.JsonCodec
- JsonLzfCodec - Class in com.github.cafapi.common.codecs.jsonlzf
-
Implementation of Codec that supports serialisation and deserialisation to and form JSON format that itself is compressed with a high-speed LZF algorithm.
- JsonLzfCodec() - Constructor for class com.github.cafapi.common.codecs.jsonlzf.JsonLzfCodec
K
- keys() - Element in annotation interface com.github.cafapi.common.api.ContainsStringKeys
L
- LEAVE_EMPTY - Enum constant in enum class com.github.workerframework.util.rabbitmq.EmptyAction
-
Do not automatically remove the queue if it becomes empty.
- LENIENT - Enum constant in enum class com.github.cafapi.common.api.DecodeMethod
-
A "lenient" Codec may accept but ignore unknown fields, and may also accept duplicate entries within the input data (though how this behaves may be undefined).
- livenessCheck() - Method in interface com.github.cafapi.common.api.HealthReporter
- livenessCheck() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
M
- main(String[]) - Static method in class com.github.cafapi.common.util.tools.EncryptData
- main(String[]) - Static method in class com.github.cafapi.common.util.tools.GenerateConfig
- main(String[]) - Static method in class com.github.workerframework.core.WorkerApplication
-
Entry point for the asynchronous micro-service worker framework.
- ManagedConfigurationSource - Interface in com.github.cafapi.common.api
- ManagedDataStore - Interface in com.github.workerframework.api
-
A DataStore with management methods for use within an application.
- ManagedWorkerQueue - Interface in com.github.workerframework.api
-
A WorkerQueue for use at an application level, supporting management methods.
- markAckEventAsSent() - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
-
Mark the ackEventSent flag to true to avoid multiple ackEventSent being sent for same inboundMessageId.
- markNegativeAckEventAsSent() - Method in class com.github.workerframework.queues.rabbit.RabbitTaskInformation
-
Mark the NegativeAckEventSent flag to true to avoid multiple NegativeAckEvent being sent for same inboundMessageId.
- message() - Element in annotation interface com.github.cafapi.common.api.ContainsStringKeys
- ModuleLoader - Class in com.github.cafapi.common.util.moduleloader
-
Utility class that provides methods for finding and returning components at runtime using the Java ServiceLoader.
- ModuleLoaderException - Exception in com.github.cafapi.common.util.moduleloader
-
Thrown when there is a problem finding or instantiating a requested component.
- ModuleLoaderException(String) - Constructor for exception com.github.cafapi.common.util.moduleloader.ModuleLoaderException
- ModuleLoaderException(String, Throwable) - Constructor for exception com.github.cafapi.common.util.moduleloader.ModuleLoaderException
- ModuleProvider - Class in com.github.cafapi.common.util.moduleloader
-
Allows retrieval of a module based on the Interface that it implements and its simple name.
N
- Name - Class in com.github.cafapi.common.util.naming
-
A class that is similar to java.naming.Name, but is iterable.
- Name(String) - Constructor for class com.github.cafapi.common.util.naming.Name
-
Create a new Name.
- Name(List<String>) - Constructor for class com.github.cafapi.common.util.naming.Name
-
Createa a new Name from a list of tokens.
- NEW_TASK - Enum constant in enum class com.github.workerframework.api.TaskStatus
-
This is a new task that requires work.
- next() - Method in class com.github.cafapi.common.util.naming.ServicePath.DescendingPathIterator
- NON_DURABLE - Enum constant in enum class com.github.workerframework.util.rabbitmq.Durability
-
The queue contents are non-durable.
- NON_EXCLUSIVE - Enum constant in enum class com.github.workerframework.util.rabbitmq.Exclusivity
-
The queue can be used by any channel consumer.
- NullCipher - Class in com.github.cafapi.common.ciphers.Null
-
Pass-through module when no encryption/decryption is desired.
- NullCipher() - Constructor for class com.github.cafapi.common.ciphers.Null.NullCipher
- NullCipherProvider - Class in com.github.cafapi.common.ciphers.Null
- NullCipherProvider() - Constructor for class com.github.cafapi.common.ciphers.Null.NullCipherProvider
- NullElection - Class in com.github.cafapi.common.elections.Null
- NullElection(ElectionCallback) - Constructor for class com.github.cafapi.common.elections.Null.NullElection
- NullElectionFactory - Class in com.github.cafapi.common.elections.Null
- NullElectionFactory() - Constructor for class com.github.cafapi.common.elections.Null.NullElectionFactory
- NullElectionFactoryProvider - Class in com.github.cafapi.common.elections.Null
- NullElectionFactoryProvider() - Constructor for class com.github.cafapi.common.elections.Null.NullElectionFactoryProvider
O
- ObjectMapperFactory - Class in com.github.cafapi.common.codecs.json
-
Provides pre-configured strict and lenient Jackson JSON ObjectMapper instances.
- ObjectMapperFactory - Class in com.github.cafapi.common.codecs.jsonlzf
-
Provides pre-configured strict and lenient Jackson JSON ObjectMapper instances.
- OLD_CONFIG_APP_NAME - Static variable in interface com.github.cafapi.common.api.BootstrapConfiguration
-
Deprecated.
- OLD_CONFIG_PATH - Static variable in class com.github.cafapi.common.config.sources.file.FileConfigurationSource
-
Deprecated.
P
- pause(TaskInformation, String, TaskMessage, Map<String, Object>) - Method in interface com.github.workerframework.api.WorkerCallback
-
Indicates the Worker wishes to forward this task to the specified paused queue without processing it.
- Paused - Enum constant in enum class com.github.workerframework.api.JobStatus
- payload() - Element in annotation interface com.github.cafapi.common.api.ContainsStringKeys
- processAck(long) - Method in class com.github.workerframework.queues.rabbit.WorkerQueueConsumerImpl
- processAck(long) - Method in interface com.github.workerframework.util.rabbitmq.QueueConsumer
-
Acknowledge a message
- processDelivery(Delivery) - Method in class com.github.workerframework.queues.rabbit.WorkerQueueConsumerImpl
-
Handle a new message from the RabbitMQ queue
- processDelivery(Delivery) - Method in interface com.github.workerframework.util.rabbitmq.QueueConsumer
-
Handle a new message from the RabbitMQ queue
- processDrop(long) - Method in class com.github.workerframework.queues.rabbit.WorkerQueueConsumerImpl
- processDrop(long) - Method in interface com.github.workerframework.util.rabbitmq.QueueConsumer
-
Drop a message
- ProcessIdentifier - Class in com.github.cafapi.common.util.processidentifier
-
Provides a unique identifier representing the current process.
- processReject(long) - Method in class com.github.workerframework.queues.rabbit.WorkerQueueConsumerImpl
- processReject(long) - Method in interface com.github.workerframework.util.rabbitmq.QueueConsumer
-
Reject a message back onto the queue
- processTasks(BulkWorkerRuntime) - Method in interface com.github.workerframework.api.BulkWorker
-
The Worker should begin processing the tasks.
- Progress - Enum constant in enum class com.github.workerframework.tracking.report.TrackingReportStatus
-
Used to report the progress of a job task.
- PropertyRetriever - Class in com.github.cafapi.common.decoders.js
-
Provides access to properties requested during decoding.
- PropertyRetriever() - Constructor for class com.github.cafapi.common.decoders.js.PropertyRetriever
- publish(TaskInformation, byte[], String, Map<String, Object>) - Method in interface com.github.workerframework.api.WorkerQueue
-
Acknowledge the original received message but send out a new message to a target queue.
- publish(TaskInformation, byte[], String, Map<String, Object>) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
- publish(TaskInformation, byte[], String, Map<String, Object>, boolean) - Method in interface com.github.workerframework.api.WorkerQueue
-
Acknowledge the original received message but send out a new message to a target queue.
- publish(TaskInformation, byte[], String, Map<String, Object>, boolean) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
- PublisherPublishEvent - Class in com.github.workerframework.util.rabbitmq
-
A publish event for a class implementing the Publisher interface.
- PublisherPublishEvent(byte[]) - Constructor for class com.github.workerframework.util.rabbitmq.PublisherPublishEvent
-
Create a new PublisherPublishEvent.
- put(URI, ByteArrayOutputStream, long, URLConnection) - Method in class com.github.workerframework.core.ResponseStreamCache
- put(URI, URLConnection) - Method in class com.github.workerframework.core.JobStatusResponseCache
Q
- QueueConsumer - Interface in com.github.workerframework.util.rabbitmq
-
The basic RabbitMQ consumer-side API methods.
- QueueCreator - Class in com.github.workerframework.util.rabbitmq
-
Builder pattern class to create queues with parameters and properties.
- QueueCreator() - Constructor for class com.github.workerframework.util.rabbitmq.QueueCreator
- QueueException - Exception in com.github.workerframework.api
-
Thrown by classes related to WorkerQueue when a request cannot be handled.
- QueueException(String) - Constructor for exception com.github.workerframework.api.QueueException
- QueueException(String, Throwable) - Constructor for exception com.github.workerframework.api.QueueException
- QueuePublisher - Interface in com.github.workerframework.util.rabbitmq
-
Simplest possible RabbitMQ publishing API
- QuietResource<T extends AutoCloseable> - Class in com.github.cafapi.common.api
-
Utility class for use with try-with-resources, for classes where the close operation may throw an exception, but this is not a useful check.
- QuietResource(T) - Constructor for class com.github.cafapi.common.api.QuietResource
R
- RABBIT_HEADER_CAF_DELIVERY_COUNT - Static variable in class com.github.workerframework.util.rabbitmq.RabbitHeaders
- RABBIT_HEADER_CAF_WORKER_REJECTED - Static variable in class com.github.workerframework.util.rabbitmq.RabbitHeaders
- RABBIT_HEADER_CAF_WORKER_RETRY - Static variable in class com.github.workerframework.util.rabbitmq.RabbitHeaders
- RABBIT_PROP_KEY_DEAD_EXCHANGE - Static variable in class com.github.workerframework.util.rabbitmq.QueueCreator
- RABBIT_PROP_KEY_DEAD_ROUTING_KEY - Static variable in class com.github.workerframework.util.rabbitmq.QueueCreator
- RABBIT_PROP_KEY_MAX_PRIORITY - Static variable in class com.github.workerframework.util.rabbitmq.QueueCreator
- RABBIT_PROP_KEY_TTL - Static variable in class com.github.workerframework.util.rabbitmq.QueueCreator
- RABBIT_PROP_QUEUE_TYPE - Static variable in class com.github.workerframework.util.rabbitmq.QueueCreator
- RABBIT_PROP_QUEUE_TYPE_CLASSIC - Static variable in class com.github.workerframework.util.rabbitmq.QueueCreator
- RABBIT_PROP_QUEUE_TYPE_QUORUM - Static variable in class com.github.workerframework.util.rabbitmq.QueueCreator
- RabbitConfiguration - Class in com.github.workerframework.configs
-
General configuration for a RabbitMQ server connection from a client.
- RabbitConfiguration() - Constructor for class com.github.workerframework.configs.RabbitConfiguration
- RabbitConsumer<T> - Class in com.github.workerframework.util.rabbitmq
-
A basic framework for handling consumption of messages from a RabbitMQ queue.
- RabbitConsumer(int, BlockingQueue<Event<T>>, T) - Constructor for class com.github.workerframework.util.rabbitmq.RabbitConsumer
-
Create a new RabbitConsumer.
- RabbitHeaders - Class in com.github.workerframework.util.rabbitmq
-
CAF RabbitMQ headers
- RabbitHeaders() - Constructor for class com.github.workerframework.util.rabbitmq.RabbitHeaders
- RabbitMetricsReporter - Class in com.github.workerframework.queues.rabbit
- RabbitMetricsReporter() - Constructor for class com.github.workerframework.queues.rabbit.RabbitMetricsReporter
- RabbitTaskInformation - Class in com.github.workerframework.queues.rabbit
- RabbitTaskInformation(String) - Constructor for class com.github.workerframework.queues.rabbit.RabbitTaskInformation
- RabbitTaskInformation(String, boolean) - Constructor for class com.github.workerframework.queues.rabbit.RabbitTaskInformation
- RabbitUtil - Class in com.github.workerframework.util.rabbitmq
-
Utility wrapper methods for interacting with RabbitMQ.
- RabbitWorkerQueue - Class in com.github.workerframework.queues.rabbit
-
This implementation uses a separate thread for a consumer and producer, each with their own Channel.
- RabbitWorkerQueue(RabbitWorkerQueueConfiguration, int) - Constructor for class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Setup a new RabbitWorkerQueue.
- RabbitWorkerQueueConfiguration - Class in com.github.workerframework.queues.rabbit
-
Configuration for the worker-queue-rabbit module.
- RabbitWorkerQueueConfiguration() - Constructor for class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- RabbitWorkerQueueProvider - Class in com.github.workerframework.queues.rabbit
- RabbitWorkerQueueProvider() - Constructor for class com.github.workerframework.queues.rabbit.RabbitWorkerQueueProvider
- reconnectIncoming() - Method in interface com.github.workerframework.api.ManagedWorkerQueue
-
Reconnects the incoming queue so tasks consumption can resume.
- reconnectIncoming() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Reconnects the incoming queue so tasks consumption can resume.
- ReferencedData - Class in com.github.cafapi.common.util.ref
-
Utility wrapper for allowing data to potentially be within a message or located on a remote DataStore.
- ReferencedObject<T> - Class in com.github.cafapi.common.util.ref
-
Utility wrapper for allowing data to potentially be within a message or located on a remote DataStore.
- ReferenceNotFoundException - Exception in com.github.workerframework.api
-
Indicates the reference passed to the DataStore did not point to any resolvable location.
- ReferenceNotFoundException(String) - Constructor for exception com.github.workerframework.api.ReferenceNotFoundException
- ReferenceNotFoundException(String, Throwable) - Constructor for exception com.github.workerframework.api.ReferenceNotFoundException
- registerNewTask(TaskInformation, byte[], Map<String, Object>) - Method in interface com.github.workerframework.api.TaskCallback
-
Announce to the worker core that a new task has been picked off the queue for processing.
- rejected() - Method in interface com.github.cafapi.common.api.ElectionCallback
-
Indicates this instance has been unelected.
- REJECTED_REASON_TASKMESSAGE - Static variable in class com.github.workerframework.queues.rabbit.WorkerQueueConsumerImpl
- rejectTask(TaskInformation) - Method in interface com.github.workerframework.api.WorkerQueue
-
Called from the asynchronous worker service to notify the queue that it is rejecting a task.
- rejectTask(TaskInformation) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Called from the asynchronous worker service to notify the queue that it is rejecting a task.
- remove(URI) - Method in class com.github.workerframework.core.ResponseStreamCache
- reportUpdate(TaskInformation, TaskMessage) - Method in interface com.github.workerframework.api.WorkerCallback
-
Used to send a report update message.
- resign() - Method in interface com.github.cafapi.common.api.Election
-
Terminate participation in this election process, withdrawing as leader if elected.
- resign() - Method in class com.github.cafapi.common.elections.Null.NullElection
- RESOURCE_PATH - Static variable in class com.github.cafapi.common.config.sources.file.FileConfigurationSource
- ResponseStreamCache - Class in com.github.workerframework.core
-
Provides in-memory caching of web responses on per-URI basis.
- ResponseStreamCache() - Constructor for class com.github.workerframework.core.ResponseStreamCache
- ResponseStreamCache.ResponseStreamCacheEntry - Class in com.github.workerframework.core
- ResponseStreamCache.SecureResponseStreamCacheEntry - Class in com.github.workerframework.core
- ResponseStreamCacheEntry(long, ByteArrayOutputStream) - Constructor for class com.github.workerframework.core.ResponseStreamCache.ResponseStreamCacheEntry
- RESULT_EXCEPTION - Enum constant in enum class com.github.workerframework.api.TaskStatus
-
The worker failed at a task because of an unhandled exception.
- RESULT_FAILURE - Enum constant in enum class com.github.workerframework.api.TaskStatus
-
The worker explicitly failed at a task.
- RESULT_HEALTHY - Static variable in class com.github.cafapi.common.api.HealthResult
- RESULT_SUCCESS - Enum constant in enum class com.github.workerframework.api.TaskStatus
-
The worker succeeded at performing a task.
- retries - Variable in class com.github.workerframework.tracking.report.TrackingReport
-
The number of attempted retries for the tracked job task.
- retrieve(String) - Method in interface com.github.workerframework.api.DataStore
-
Provide a stream to get data by reference
- retrieve(String) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
-
Provide a stream to get data by reference
- retrieve(String) - Method in class com.github.workerframework.datastores.http.HttpDataStore
- retrieve(String) - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Provide a stream to get data identified by the reference.
- retrieve(String) - Method in class com.github.workerframework.datastores.s3.S3DataStore
- Retry - Enum constant in enum class com.github.workerframework.tracking.report.TrackingReportStatus
-
Used to report the failure and retry of a job task.
- run() - Method in class com.github.workerframework.util.rabbitmq.EventPoller
-
Start a thread that will poll with the period specified when the object was created.
- run(WorkerConfiguration, Environment) - Method in class com.github.workerframework.core.WorkerApplication
-
Start the asynchronous worker micro-service.
S
- S3DataStore - Class in com.github.workerframework.datastores.s3
-
ManagedDataStore implementation for Amazon S3.
- S3DataStore(S3DataStoreConfiguration) - Constructor for class com.github.workerframework.datastores.s3.S3DataStore
- S3DataStoreConfiguration - Class in com.github.workerframework.datastores.s3
- S3DataStoreConfiguration() - Constructor for class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- S3DataStoreProvider - Class in com.github.workerframework.datastores.s3
- S3DataStoreProvider() - Constructor for class com.github.workerframework.datastores.s3.S3DataStoreProvider
- SecretRetriever - Class in com.github.cafapi.common.decoders.js
-
Provides access to secrets requested during decoding.
- SecretRetriever() - Constructor for class com.github.cafapi.common.decoders.js.SecretRetriever
- SecretUtil - Class in com.github.cafapi.common.util.secret
- SecureResponseStreamCacheEntry(long, ByteArrayOutputStream, String, List<Certificate>, List<Certificate>, Principal, Principal) - Constructor for class com.github.workerframework.core.ResponseStreamCache.SecureResponseStreamCacheEntry
- send(TaskInformation, TaskMessage) - Method in interface com.github.workerframework.api.WorkerCallback
-
Used to send responses prior to the final response (when complete should be used instead).
- sendMessage(TaskMessage) - Method in interface com.github.workerframework.api.WorkerTaskData
-
Used when a task message needs to be published on the messaging queue.
- serialise(Object) - Method in class com.github.cafapi.common.codecs.json.JsonCodec
- serialise(Object) - Method in class com.github.cafapi.common.codecs.jsonlzf.JsonLzfCodec
- serialise(T) - Method in interface com.github.cafapi.common.api.Codec
-
Serialise the given object into a byte data form.
- ServicePath - Class in com.github.cafapi.common.util.naming
-
Simple object to store the service path, expected to be in the form /group/subgroup/id.
- ServicePath(String) - Constructor for class com.github.cafapi.common.util.naming.ServicePath
-
Create a new ServicePath from a String.
- ServicePath.DescendingPathIterator - Class in com.github.cafapi.common.util.naming
- setAccessKey(String) - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- setBackoffInterval(int) - Method in class com.github.workerframework.configs.RabbitConfiguration
- setBucketName(String) - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- setConnectTimeoutMillis(Integer) - Method in class com.github.workerframework.datastores.http.HttpDataStoreConfiguration
- setContext(Map<String, byte[]>) - Method in class com.github.workerframework.api.TaskMessage
- setCorrelationId(String) - Method in class com.github.workerframework.api.TaskMessage
- setDataDir(String) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStoreConfiguration
- setDataDirHealthcheckTimeoutSeconds(Integer) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStoreConfiguration
- setDelaySeconds(int) - Method in class com.github.workerframework.testworker.TestWorkerTask
- setInputQueue(String) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- setJobTaskId(String) - Method in class com.github.workerframework.api.TrackingInfo
- setLastStatusCheckTime(Date) - Method in class com.github.workerframework.api.TrackingInfo
- setLivenessCheckIntervalSeconds(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setLivenessDowntimeIntervalSeconds(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setLivenessFailureAttempts(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setLivenessInitialDelaySeconds(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setLivenessSuccessAttempts(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setMaxAttempts(int) - Method in class com.github.workerframework.configs.RabbitConfiguration
- setMaxBackoffInterval(int) - Method in class com.github.workerframework.configs.RabbitConfiguration
- setMaxPriority(int) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- setName(String) - Method in class com.github.workerframework.api.TaskSourceInfo
- setOutputBufferSize(Integer) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStoreConfiguration
- setPausedQueue(String) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- setPoison(boolean) - Method in class com.github.workerframework.testworker.TestWorkerTask
- setPrefetchBuffer(int) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- setPriority(Integer) - Method in class com.github.workerframework.api.TaskMessage
- setProxyHost(String) - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- setProxyPort(int) - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- setProxyProtocol(String) - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- setQueueType(String) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- setRabbitConfiguration(RabbitConfiguration) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- setRabbitHost(String) - Method in class com.github.workerframework.configs.RabbitConfiguration
- setRabbitPassword(String) - Method in class com.github.workerframework.configs.RabbitConfiguration
- setRabbitPort(int) - Method in class com.github.workerframework.configs.RabbitConfiguration
- setRabbitProtocol(String) - Method in class com.github.workerframework.configs.RabbitConfiguration
- setRabbitUser(String) - Method in class com.github.workerframework.configs.RabbitConfiguration
- setReadinessCheckIntervalSeconds(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setReadinessDowntimeIntervalSeconds(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setReadinessFailureAttempts(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setReadinessInitialDelaySeconds(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setReadinessSuccessAttempts(int) - Method in class com.github.workerframework.configs.HealthConfiguration
- setReadTimeoutMillis(int) - Method in class com.github.workerframework.datastores.http.HttpDataStoreConfiguration
- setRejectedQueue(String) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
-
Deprecated.
- setRejectQueue(String) - Method in class com.github.workerframework.api.WorkerConfiguration
- setResponse(InvalidTaskException) - Method in interface com.github.workerframework.api.WorkerTask
-
Used by the Worker to declare that the task is not valid
- setResponse(TaskRejectedException) - Method in interface com.github.workerframework.api.WorkerTask
-
Used by the Worker to reject the task
- setResponse(WorkerResponse) - Method in interface com.github.workerframework.api.WorkerTask
-
Used by the Worker to set the response to the task.
- setRetryLimit(int) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- setRetryQueue(String) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueueConfiguration
- setSecretKey(String) - Method in class com.github.workerframework.datastores.s3.S3DataStoreConfiguration
- setSourceInfo(TaskSourceInfo) - Method in class com.github.workerframework.api.TaskMessage
- setStatusCheckIntervalMillis(long) - Method in class com.github.workerframework.api.TrackingInfo
- setStatusCheckUrl(String) - Method in class com.github.workerframework.api.TrackingInfo
- setTaskApiVersion(int) - Method in class com.github.workerframework.api.TaskMessage
- setTaskClassifier(String) - Method in class com.github.workerframework.api.TaskMessage
- setTaskData(byte[]) - Method in class com.github.workerframework.api.TaskMessage
- setTaskId(String) - Method in class com.github.workerframework.api.TaskMessage
- setTaskStatus(TaskStatus) - Method in class com.github.workerframework.api.TaskMessage
- setTo(String) - Method in class com.github.workerframework.api.TaskMessage
- setTracking(TrackingInfo) - Method in class com.github.workerframework.api.TaskMessage
- setTrackingPipe(String) - Method in class com.github.workerframework.api.TrackingInfo
- setTrackTo(String) - Method in class com.github.workerframework.api.TrackingInfo
- setUrl(String) - Method in class com.github.workerframework.datastores.http.HttpDataStoreConfiguration
- setVersion(int) - Method in class com.github.workerframework.api.TaskMessage
- setVersion(String) - Method in class com.github.workerframework.api.TaskSourceInfo
- setWorkerName(String) - Method in class com.github.workerframework.api.WorkerConfiguration
- setWorkerVersion(String) - Method in class com.github.workerframework.api.WorkerConfiguration
- shutdown() - Method in interface com.github.cafapi.common.api.ManagedConfigurationSource
-
Perform necessary shutdown operations.
- shutdown() - Method in class com.github.cafapi.common.config.sources.file.FileConfigurationSource
- shutdown() - Method in interface com.github.workerframework.api.ManagedDataStore
-
Perform necessary shut down operations.
- shutdown() - Method in interface com.github.workerframework.api.ManagedWorkerQueue
-
Terminate all queue operations.
- shutdown() - Method in interface com.github.workerframework.api.WorkerFactory
-
Perform necessary cleanup of resources that the WorkerFactory was using.
- shutdown() - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
- shutdown() - Method in class com.github.workerframework.datastores.http.HttpDataStore
- shutdown() - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Perform necessary shut down operations.
- shutdown() - Method in class com.github.workerframework.datastores.s3.S3DataStore
- shutdown() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
- shutdown() - Method in class com.github.workerframework.util.rabbitmq.EventPoller
-
Signal the termination of the EventPoller.
- shutdownIncoming() - Method in interface com.github.workerframework.api.ManagedWorkerQueue
-
Halt the incoming queue so that no more tasks are picked up.
- shutdownIncoming() - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Halt the incoming queue so that no more tasks are picked up.
- size() - Method in class com.github.cafapi.common.util.naming.Name
- size(DataSource) - Method in class com.github.cafapi.common.util.ref.ReferencedData
-
Determine the size of the data.
- size(String) - Method in interface com.github.workerframework.api.DataStore
-
Get the byte size of some data in the DataStore by reference
- size(String) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
- size(String) - Method in class com.github.workerframework.datastores.http.HttpDataStore
- size(String) - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Return the byte size of the data identified by the reference.
- size(String) - Method in class com.github.workerframework.datastores.s3.S3DataStore
- SourceNotFoundException - Exception in com.github.cafapi.common.util.ref
-
Thrown when the source reference is not found.
- SourceNotFoundException(String) - Constructor for exception com.github.cafapi.common.util.ref.SourceNotFoundException
- SourceNotFoundException(String, Throwable) - Constructor for exception com.github.cafapi.common.util.ref.SourceNotFoundException
- stackTraceToString(StackTraceElement[]) - Method in class com.github.workerframework.caf.AbstractWorker
- start(TaskCallback) - Method in interface com.github.workerframework.api.ManagedWorkerQueue
-
Open queues to start accepting tasks and results.
- start(TaskCallback) - Method in class com.github.workerframework.queues.rabbit.RabbitWorkerQueue
-
Open queues to start accepting tasks and results.
- status - Variable in class com.github.workerframework.tracking.report.TrackingReport
-
Specifies how the job task should be reported.
- store(byte[], String) - Method in interface com.github.workerframework.api.DataStore
-
Store data from a byte array.
- store(byte[], String) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
- store(byte[], String) - Method in class com.github.workerframework.datastores.http.HttpDataStore
- store(byte[], String) - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Store data from a byte array in the key given by the partial reference.
- store(byte[], String) - Method in class com.github.workerframework.datastores.s3.S3DataStore
- store(InputStream, String) - Method in interface com.github.workerframework.api.DataStore
-
Store data from a stream, which should be closed by the caller.
- store(InputStream, String) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
- store(InputStream, String) - Method in class com.github.workerframework.datastores.http.HttpDataStore
- store(InputStream, String) - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Store data from a stream in the key given by the partial reference.
- store(InputStream, String) - Method in class com.github.workerframework.datastores.s3.S3DataStore
- store(String, Consumer<String>) - Method in interface com.github.workerframework.api.DataStoreOutputStreamSupport
-
Opens an output stream which the caller can use to store data.
- store(String, Consumer<String>) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
- store(Path, String) - Method in interface com.github.workerframework.api.DataStore
-
Store data from a local file.
- store(Path, String) - Method in class com.github.workerframework.datastores.fs.FileSystemDataStore
- store(Path, String) - Method in class com.github.workerframework.datastores.http.HttpDataStore
- store(Path, String) - Method in class com.github.workerframework.datastores.mem.InMemoryDataStore
-
Store data from a local file in the key given by the partial reference.
- store(Path, String) - Method in class com.github.workerframework.datastores.s3.S3DataStore
- STRICT - Enum constant in enum class com.github.cafapi.common.api.DecodeMethod
-
A "strict" Codec should not allow unknown fields.
- SystemBootstrapConfiguration - Class in com.github.cafapi.common.bootstrapconfigs.system
-
Provides bootstrap configuration from Java system properties and environment variables.
- SystemBootstrapConfiguration() - Constructor for class com.github.cafapi.common.bootstrapconfigs.system.SystemBootstrapConfiguration
T
- TASK_MESSAGE_VERSION - Static variable in class com.github.workerframework.api.TaskMessage
- TaskCallback - Interface in com.github.workerframework.api
-
A callback interface used to announce the arrival of a new task for a worker to process or signal that the core should cancel its tasks.
- TaskFailedException - Exception in com.github.workerframework.api
-
An unchecked exception to throw if a Worker fails its task in an unrecoverable way.
- TaskFailedException(String) - Constructor for exception com.github.workerframework.api.TaskFailedException
- TaskFailedException(String, Throwable) - Constructor for exception com.github.workerframework.api.TaskFailedException
- TaskInformation - Interface in com.github.workerframework.api
- TaskMessage - Class in com.github.workerframework.api
-
The generic task message class to be serialised from or to a queue.
- TaskMessage() - Constructor for class com.github.workerframework.api.TaskMessage
- TaskMessage(String, String, int, byte[], TaskStatus, Map<String, byte[]>) - Constructor for class com.github.workerframework.api.TaskMessage
- TaskMessage(String, String, int, byte[], TaskStatus, Map<String, byte[]>, String) - Constructor for class com.github.workerframework.api.TaskMessage
- TaskMessage(String, String, int, byte[], TaskStatus, Map<String, byte[]>, String, TrackingInfo) - Constructor for class com.github.workerframework.api.TaskMessage
- TaskMessage(String, String, int, byte[], TaskStatus, Map<String, byte[]>, String, TrackingInfo, TaskSourceInfo) - Constructor for class com.github.workerframework.api.TaskMessage
- TaskMessage(String, String, int, byte[], TaskStatus, Map<String, byte[]>, String, TrackingInfo, TaskSourceInfo, String) - Constructor for class com.github.workerframework.api.TaskMessage
- TaskMessageForwardingEvaluator - Interface in com.github.workerframework.api
-
Deprecated.
- TaskRejectedException - Exception in com.github.workerframework.api
-
Indicates that a task cannot be accepted right now, but that it should be retried at a later time.
- TaskRejectedException(String) - Constructor for exception com.github.workerframework.api.TaskRejectedException
- TaskRejectedException(String, Throwable) - Constructor for exception com.github.workerframework.api.TaskRejectedException
- TaskSourceInfo - Class in com.github.workerframework.api
-
Records information about the agent that initiated a task message.
- TaskSourceInfo() - Constructor for class com.github.workerframework.api.TaskSourceInfo
- TaskSourceInfo(String, String) - Constructor for class com.github.workerframework.api.TaskSourceInfo
- TaskStatus - Enum Class in com.github.workerframework.api
-
The state of a worker thread upon termination.
- TestWorkerFactoryProvider - Class in com.github.workerframework.testworker
-
Simple test worker used for testing the Worker Framework.
- TestWorkerFactoryProvider() - Constructor for class com.github.workerframework.testworker.TestWorkerFactoryProvider
- TestWorkerTask - Class in com.github.workerframework.testworker
- TestWorkerTask() - Constructor for class com.github.workerframework.testworker.TestWorkerTask
- toString() - Method in class com.github.cafapi.common.util.naming.Name
- toString() - Method in class com.github.cafapi.common.util.naming.ServicePath
- TRACKING_REPORT_TASK_API_VER - Static variable in class com.github.workerframework.tracking.report.TrackingReportConstants
-
The numeric API version of the message task.
- TRACKING_REPORT_TASK_NAME - Static variable in class com.github.workerframework.tracking.report.TrackingReportConstants
-
Identifies the sort of task this message is.
- TrackingInfo - Class in com.github.workerframework.api
-
Holds fields used in tracking task messages, for Progress Reporting and Job Control.
- TrackingInfo() - Constructor for class com.github.workerframework.api.TrackingInfo
- TrackingInfo(TrackingInfo) - Constructor for class com.github.workerframework.api.TrackingInfo
- TrackingInfo(String, Date, long, String, String, String) - Constructor for class com.github.workerframework.api.TrackingInfo
- TrackingReport - Class in com.github.workerframework.tracking.report
-
Holds tracking report data.
- TrackingReport() - Constructor for class com.github.workerframework.tracking.report.TrackingReport
- TrackingReportConstants - Class in com.github.workerframework.tracking.report
- TrackingReportFailure - Class in com.github.workerframework.tracking.report
-
Holds the tracked job task failure details in the event of an invalid task or exception.
- TrackingReportFailure() - Constructor for class com.github.workerframework.tracking.report.TrackingReportFailure
- trackingReports - Variable in class com.github.workerframework.tracking.report.TrackingReportTask
-
The tracked job tasks whose progress is being reported.
- TrackingReportStatus - Enum Class in com.github.workerframework.tracking.report
-
Enumeration indicating how the tracked job task should be reported.
- TrackingReportTask - Class in com.github.workerframework.tracking.report
-
This task is used to report on the progress of a number of tracked job tasks.
- TrackingReportTask() - Constructor for class com.github.workerframework.tracking.report.TrackingReportTask
- TransientHealthCheck - Class in com.github.workerframework.core
- TransientHealthCheck() - Constructor for class com.github.workerframework.core.TransientHealthCheck
U
- UNHEALTHY - Enum constant in enum class com.github.cafapi.common.api.HealthStatus
-
The service is unhealthy or failed in some manner.
- UNKNOWN - Enum constant in enum class com.github.cafapi.common.api.HealthStatus
-
The health could not be determined at this time.
V
- value() - Element in annotation interface com.github.cafapi.common.api.FileExtensions
- valueOf(String) - Static method in enum class com.github.cafapi.common.api.DecodeMethod
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.cafapi.common.api.HealthStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.workerframework.api.DivertedTaskAction
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.workerframework.api.JobStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.workerframework.api.TaskStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.workerframework.tracking.report.TrackingReportStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.workerframework.util.rabbitmq.Durability
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.workerframework.util.rabbitmq.EmptyAction
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.workerframework.util.rabbitmq.Exclusivity
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class com.github.cafapi.common.api.DecodeMethod
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.cafapi.common.api.HealthStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.workerframework.api.DivertedTaskAction
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.workerframework.api.JobStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.workerframework.api.TaskStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.workerframework.tracking.report.TrackingReportStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.workerframework.util.rabbitmq.Durability
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.workerframework.util.rabbitmq.EmptyAction
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.workerframework.util.rabbitmq.Exclusivity
-
Returns an array containing the constants of this enum class, in the order they are declared.
- verifyWorkerTask(WorkerTask) - Method in class com.github.workerframework.caf.AbstractWorkerFactory
-
Verify that the specified worker task has the right type and is a version that can be handled.
- verifyWorkerTaskAndSetResponse(WorkerTask) - Method in class com.github.workerframework.caf.AbstractWorkerFactory
-
Verify that the specified worker task has the right type and is a version that can be handled.
W
- Waiting - Enum constant in enum class com.github.workerframework.api.JobStatus
- withDeadLetterExchange(String) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
- withDeadLetterRoutingKey(String) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
- withdraw() - Method in interface com.github.cafapi.common.api.Election
-
Request withdrawal as leader, triggering a re-election process.
- withdraw() - Method in class com.github.cafapi.common.elections.Null.NullElection
- withDurability(Durability) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
- withEmptyAction(EmptyAction) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
- withExclusivity(Exclusivity) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
- withQueueName(String) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
- withQueueTtl(long) - Method in class com.github.workerframework.util.rabbitmq.QueueCreator
- Worker - Interface in com.github.workerframework.api
-
A Worker can be constructed in any way as per suits the developer, but should only perform the bare minimum of tasks in the constructor to set itself up to perform the computational work.
- WorkerApplication - Class in com.github.workerframework.core
-
This is the main SaaS asynchronous micro-service worker entry point.
- WorkerCallback - Interface in com.github.workerframework.api
-
The callback interface for a task to report it is complete or that it must be subject to some further action, e.g.
- WorkerConfiguration - Class in com.github.workerframework.api
- WorkerConfiguration - Class in com.github.workerframework.core
- WorkerConfiguration() - Constructor for class com.github.workerframework.api.WorkerConfiguration
- WorkerConfiguration() - Constructor for class com.github.workerframework.core.WorkerConfiguration
- WorkerConnectionListener - Class in com.github.workerframework.queues.rabbit
-
Trivial ConnectionListener primarily to handle aborting in-progress tasks when the RabbitMQ connection is recovered - this is because RabbitMQ will automatically re-queue the message when it detected our client dropped, and we don't want to produce a result for these tasks running when the connection dropped to try and avoid duplicate results.
- WorkerConnectionListener(TaskCallback, WorkerConfirmListener) - Constructor for class com.github.workerframework.queues.rabbit.WorkerConnectionListener
- WorkerException - Exception in com.github.workerframework.api
-
Thrown by classes related to Worker when a request cannot be handled.
- WorkerException(String) - Constructor for exception com.github.workerframework.api.WorkerException
- WorkerException(String, Throwable) - Constructor for exception com.github.workerframework.api.WorkerException
- WorkerFactory - Interface in com.github.workerframework.api
-
Instantiates a new instance of a Worker given task-specific data.
- WorkerFactoryProvider - Interface in com.github.workerframework.api
-
The responsibility of a WorkerFactory is to provide a mechanism to generate new Worker objects and specify how many simultaneous workers should be running.
- WorkerPublisher - Interface in com.github.workerframework.queues.rabbit
-
A publisher that publishes to a specific queue and acknowledges another message subsequent to publishing.
- WorkerPublisherImpl - Class in com.github.workerframework.queues.rabbit
-
A RabbitMQ publisher that uses a ConfirmListener, sending data as plain text with headers.
- WorkerPublisherImpl(Channel, RabbitMetricsReporter, BlockingQueue<Event<QueueConsumer>>, WorkerConfirmListener) - Constructor for class com.github.workerframework.queues.rabbit.WorkerPublisherImpl
-
Create a WorkerPublisher implementation.
- WorkerPublishQueueEvent - Class in com.github.workerframework.queues.rabbit
-
Event for publishing via a WorkerPublisher.
- WorkerPublishQueueEvent(byte[], String, RabbitTaskInformation) - Constructor for class com.github.workerframework.queues.rabbit.WorkerPublishQueueEvent
- WorkerPublishQueueEvent(byte[], String, RabbitTaskInformation, Map<String, Object>) - Constructor for class com.github.workerframework.queues.rabbit.WorkerPublishQueueEvent
-
Create a new WorkerPublishQueueEvent
- WorkerQueue - Interface in com.github.workerframework.api
-
A general representation of a queue for the purposes of a worker service.
- WorkerQueueConsumerImpl - Class in com.github.workerframework.queues.rabbit
-
QueueConsumer implementation for a WorkerQueue.
- WorkerQueueConsumerImpl(TaskCallback, RabbitMetricsReporter, BlockingQueue<Event<QueueConsumer>>, Channel, BlockingQueue<Event<WorkerPublisher>>, String, int) - Constructor for class com.github.workerframework.queues.rabbit.WorkerQueueConsumerImpl
- WorkerQueueMetricsReporter - Interface in com.github.workerframework.api
-
Provides metrics for a WorkerQueue.
- WorkerQueueProvider - Interface in com.github.workerframework.api
-
Boilerplate for retrieving a WorkerQueue implementation.
- WorkerResponse - Class in com.github.workerframework.api
-
Object to represent a response from a Worker, to be interpreted by the core worker framework.
- WorkerResponse(String, TaskStatus, byte[], String, int, byte[]) - Constructor for class com.github.workerframework.api.WorkerResponse
-
Create a new WorkerResponse.
- WorkerResponse(String, TaskStatus, byte[], String, int, byte[], String) - Constructor for class com.github.workerframework.api.WorkerResponse
-
Create a new WorkerResponse.
- WorkerTask - Interface in com.github.workerframework.api
-
Provides access onto Worker Task Data and ability to set response.
- WorkerTaskData - Interface in com.github.workerframework.api
-
Represents a task to be completed by the CAF Worker.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
DivertedTaskHandler
instead.