A B C D E F G H I L M N O P Q R S T U V W
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- ALLOW - ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WaitInterrupt
-
Прерывание разрешено
- ARITHMETIC - ru.yoomoney.tech.dbqueue.settings.ReenqueueRetryType
-
The task is deferred by the delay set using an arithmetic progression.
- ARITHMETIC_BACKOFF - ru.yoomoney.tech.dbqueue.settings.FailRetryType
-
The task is deferred by an arithmetic progression relative to the interval
FailureSettings.getRetryInterval()
. - asString() - Method in class ru.yoomoney.tech.dbqueue.config.QueueShardId
-
Get shard identifier.
- asString() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueId
-
Get string representation of queue identifier.
- awaitTermination(Duration) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Wait for tasks (and threads) termination in all queues within given timeout.
- awaitTermination(QueueId, Duration) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Wait for tasks (and threads) termination in specified queue within given timeout.
B
- BaseQueueRunner - Class in ru.yoomoney.tech.dbqueue.internal.runner
-
Базовая реализация обработчика задач очереди
- build() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult.Builder
- build() - Method in class ru.yoomoney.tech.dbqueue.api.Task.Builder
- build() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- build() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- build() - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings.Builder
- build() - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings.Builder
-
Create new failure settings object.
- build() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings.Builder
-
Create new poll settings object.
- build() - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings.Builder
- build() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation.Builder
-
Build queue location object.
- build() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings.Builder
-
Create new queue settings object.
- build() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings.Builder
- builder() - Static method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult
-
Creates builder for
EnqueueResult
object - builder() - Static method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
- builder() - Static method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
- builder() - Static method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
-
Create a new builder for ext settings.
- builder() - Static method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
-
Create a new builder for failure settings.
- builder() - Static method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
-
Create a new builder for poll settings.
- builder() - Static method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
-
Create a new builder for processing settings.
- builder() - Static method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation
-
Create a new builder for queue location.
- builder() - Static method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
-
Create a new builder for queue settings.
- builder() - Static method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
- builder(QueueShardId) - Static method in class ru.yoomoney.tech.dbqueue.api.Task
-
Creates a builder for
Task
objects. - Builder() - Constructor for class ru.yoomoney.tech.dbqueue.settings.FailureSettings.Builder
- Builder() - Constructor for class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings.Builder
C
- calculateDelay(TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.ReenqueueRetryStrategy.ArithmeticReenqueueRetryStrategy
- calculateDelay(TaskRecord) - Method in interface ru.yoomoney.tech.dbqueue.internal.processing.ReenqueueRetryStrategy
-
Вычисляет задержку перед следующим выполнением задачи.
- calculateDelay(TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.ReenqueueRetryStrategy.FixedDelayReenqueueRetryStrategy
- calculateDelay(TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.ReenqueueRetryStrategy.GeometricReenqueueRetryStrategy
- calculateDelay(TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.ReenqueueRetryStrategy.ManualReenqueueRetryStrategy
- calculateDelay(TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.ReenqueueRetryStrategy.SequentialReenqueueRetryStrategy
- CompositeTaskLifecycleListener - Class in ru.yoomoney.tech.dbqueue.config.impl
-
Composite listener.
- CompositeTaskLifecycleListener(List<TaskLifecycleListener>) - Constructor for class ru.yoomoney.tech.dbqueue.config.impl.CompositeTaskLifecycleListener
-
Constructor
- CompositeThreadLifecycleListener - Class in ru.yoomoney.tech.dbqueue.config.impl
-
Composite listener.
- CompositeThreadLifecycleListener(List<ThreadLifecycleListener>) - Constructor for class ru.yoomoney.tech.dbqueue.config.impl.CompositeThreadLifecycleListener
-
Constructor
- copyFields(ExtSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
- copyFields(FailureSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
- copyFields(PollSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
- copyFields(ProcessingSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
- copyFields(ReenqueueSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
- crashed(QueueShardId, QueueLocation, Throwable) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeThreadLifecycleListener
- crashed(QueueShardId, QueueLocation, Throwable) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingThreadLifecycleListener
- crashed(QueueShardId, QueueLocation, Throwable) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopThreadLifecycleListener
- crashed(QueueShardId, QueueLocation, Throwable) - Method in interface ru.yoomoney.tech.dbqueue.config.ThreadLifecycleListener
-
Queue failed with fatal error.
- crashed(QueueShardId, QueueLocation, TaskRecord, Exception) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeTaskLifecycleListener
- crashed(QueueShardId, QueueLocation, TaskRecord, Exception) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingTaskLifecycleListener
- crashed(QueueShardId, QueueLocation, TaskRecord, Exception) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopTaskLifecycleListener
- crashed(QueueShardId, QueueLocation, TaskRecord, Exception) - Method in interface ru.yoomoney.tech.dbqueue.config.TaskLifecycleListener
-
Event for abnormal queue processing.
- create(PayloadBuilderT) - Static method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
-
Create new task parameters with payload
- create(QueueConsumer, QueueShard<?>, TaskLifecycleListener) - Static method in class ru.yoomoney.tech.dbqueue.internal.runner.QueueRunner.Factory
-
Создать исполнителя задач очереди
- create(ReenqueueSettings) - Static method in class ru.yoomoney.tech.dbqueue.internal.processing.ReenqueueRetryStrategy.Factory
-
Создает стратегию на основе переданных настроек переоткладывания задач для очереди.
- createQueuePickTaskDao(QueueLocation, FailureSettings) - Method in interface ru.yoomoney.tech.dbqueue.config.DatabaseAccessLayer
-
Create an instance of database-specific DAO based on database type and table schema.
D
- DatabaseAccessLayer - Interface in ru.yoomoney.tech.dbqueue.config
-
Interface for interacting with database
- DatabaseDialect - Enum in ru.yoomoney.tech.dbqueue.config
-
Supported database type (dialect)
- deleteTask(QueueLocation, long) - Method in interface ru.yoomoney.tech.dbqueue.dao.QueueDao
-
Remove (delete) task from the queue.
- DENY - ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WaitInterrupt
-
Прерывание запрещено
- doContinue() - Method in interface ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop
-
Продолжить исполнение кода
- doContinue() - Method in class ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WakeupQueueLoop
- doRun(Runnable) - Method in interface ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop
-
Запустить выполнение кода
- doRun(Runnable) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WakeupQueueLoop
- doWait(Duration, QueueLoop.WaitInterrupt) - Method in interface ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop
-
Приостановить исполнение кода
- doWait(Duration, QueueLoop.WaitInterrupt) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WakeupQueueLoop
E
- enqueue(EnqueueParams<PayloadT>) - Method in class ru.yoomoney.tech.dbqueue.api.impl.MonitoringQueueProducer
- enqueue(EnqueueParams<PayloadT>) - Method in interface ru.yoomoney.tech.dbqueue.api.QueueProducer
-
Add a new task into the queue
- enqueue(EnqueueParams<PayloadTaskT>) - Method in class ru.yoomoney.tech.dbqueue.api.impl.ShardingQueueProducer
- enqueue(QueueLocation, EnqueueParams<String>) - Method in interface ru.yoomoney.tech.dbqueue.dao.QueueDao
-
Add a new task in the queue for processing.
- EnqueueParams<PayloadT> - Class in ru.yoomoney.tech.dbqueue.api
-
Parameters with typed payload to enqueue the task
- EnqueueParams() - Constructor for class ru.yoomoney.tech.dbqueue.api.EnqueueParams
- EnqueueResult - Class in ru.yoomoney.tech.dbqueue.api
-
Task enqueue result
- EnqueueResult(QueueShardId, Long) - Constructor for class ru.yoomoney.tech.dbqueue.api.EnqueueResult
-
Constructor
- EnqueueResult.Builder - Class in ru.yoomoney.tech.dbqueue.api
-
Builder for the
EnqueueResult
object. - equals(Object) - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.api.Task
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.config.QueueShardId
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfig
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueId
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
- equals(Object) - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
- execute(Consumer<Duration>) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.TimeLimiter
-
Выполнить действие с контролем времени.
- execute(Task<PayloadT>) - Method in interface ru.yoomoney.tech.dbqueue.api.QueueConsumer
-
Process the task from the queue
- executed(QueueShardId, QueueLocation, boolean, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeThreadLifecycleListener
- executed(QueueShardId, QueueLocation, boolean, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingThreadLifecycleListener
- executed(QueueShardId, QueueLocation, boolean, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopThreadLifecycleListener
- executed(QueueShardId, QueueLocation, boolean, long) - Method in interface ru.yoomoney.tech.dbqueue.config.ThreadLifecycleListener
-
Thread was executed and finished processing.
- executed(QueueShardId, QueueLocation, TaskRecord, TaskExecutionResult, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeTaskLifecycleListener
- executed(QueueShardId, QueueLocation, TaskRecord, TaskExecutionResult, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingTaskLifecycleListener
- executed(QueueShardId, QueueLocation, TaskRecord, TaskExecutionResult, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopTaskLifecycleListener
- executed(QueueShardId, QueueLocation, TaskRecord, TaskExecutionResult, long) - Method in interface ru.yoomoney.tech.dbqueue.config.TaskLifecycleListener
-
Event for completion of client logic when task processing.
- ExtSettings - Class in ru.yoomoney.tech.dbqueue.settings
-
Additional custom settings
- ExtSettings.Builder - Class in ru.yoomoney.tech.dbqueue.settings
-
A builder for ext settings.
F
- fail() - Static method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
-
Instruction to execute the task again later according to the
re-enqueue strategy
established in the queue configuration. - FAIL - ru.yoomoney.tech.dbqueue.api.TaskExecutionResult.Type
-
Notify on error task execution, task will be postponed and executed again
- FailRetryType - Enum in ru.yoomoney.tech.dbqueue.settings
-
Strategy type for the task deferring in case of retry.
- FailureSettings - Class in ru.yoomoney.tech.dbqueue.settings
-
Settings for task execution strategy in case of failure.
- FailureSettings.Builder - Class in ru.yoomoney.tech.dbqueue.settings
-
A builder for failure settings.
- finish() - Static method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
-
Instruction to finish task processing and remove the task from the queue
- FINISH - ru.yoomoney.tech.dbqueue.api.TaskExecutionResult.Type
-
Finish the task, task will be removed from the queue
- finished(QueueShardId, QueueLocation) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeThreadLifecycleListener
- finished(QueueShardId, QueueLocation) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingThreadLifecycleListener
- finished(QueueShardId, QueueLocation) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopThreadLifecycleListener
- finished(QueueShardId, QueueLocation) - Method in interface ru.yoomoney.tech.dbqueue.config.ThreadLifecycleListener
-
End of the task processing lifecycle and start of the new one.
- finished(QueueShardId, QueueLocation, TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeTaskLifecycleListener
- finished(QueueShardId, QueueLocation, TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingTaskLifecycleListener
- finished(QueueShardId, QueueLocation, TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopTaskLifecycleListener
- finished(QueueShardId, QueueLocation, TaskRecord) - Method in interface ru.yoomoney.tech.dbqueue.config.TaskLifecycleListener
-
Event for completion the task execution in the queue.
- FIXED - ru.yoomoney.tech.dbqueue.settings.ReenqueueRetryType
-
The task is deferred by the fixed delay, which is set in configuration.
- fromObject(String) - Method in class ru.yoomoney.tech.dbqueue.api.impl.NoopPayloadTransformer
- fromObject(PayloadT) - Method in interface ru.yoomoney.tech.dbqueue.api.TaskPayloadTransformer
-
Marshall the typed object with task parameters into string payload.
G
- GEOMETRIC - ru.yoomoney.tech.dbqueue.settings.ReenqueueRetryType
-
The task is deferred by the delay set using a geometric progression The term of progression selected according to
the number of attempt to postpone the task processing
. - GEOMETRIC_BACKOFF - ru.yoomoney.tech.dbqueue.settings.FailRetryType
-
The task is deferred exponentially relative to the interval
FailureSettings.getRetryInterval()
The denominator of the progression equals 2. - getActionType() - Method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
-
Get action, which should be performed after the task processing.
- getArithmeticStepOrThrow() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
-
The difference of the arithmetic progression.
- getAttemptField() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Field with a column name for task execution attempts count.
- getAttemptsCount() - Method in class ru.yoomoney.tech.dbqueue.api.Task
-
Get number of attempts to execute the task, including the current one.
- getAttemptsCount() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
-
Get number of attempts to execute the task, including the current one.
- getBetweenTaskTimeout() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
-
Get delay duration between picking tasks from the queue after the task was processed.
- getConfigPaths() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Get paths to queue configs
- getCreatedAt() - Method in class ru.yoomoney.tech.dbqueue.api.Task
-
Get date and time when the task was added into the queue.
- getCreatedAt() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
-
Get date and time when the task was added into the queue.
- getCreatedAtField() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Field with a column name for task creation date and time.
- getDatabaseAccessLayer() - Method in class ru.yoomoney.tech.dbqueue.config.QueueShard
-
Get database access layer.
- getDatabaseDialect() - Method in interface ru.yoomoney.tech.dbqueue.config.DatabaseAccessLayer
-
Get database type for that database.
- getDiffEvaluator() - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
- getDiffEvaluator() - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
- getDiffEvaluator() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
- getDiffEvaluator() - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
- getDiffEvaluator() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
- getDurationProperty(String) - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
-
Get Duration value of additional queue property.
- getEnqueueId() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult
-
Identifier (sequence id) of added task
- getExecutionDelay() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
-
Get the task execution delay, a Duration.ZERO is the default one if not set.
- getExecutionDelay() - Method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
-
Get task execution delay.
- getExecutionDelayOrThrow() - Method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
-
Get task execution delay or throw an IllegalStateException when task execution delay is not present.
- getExecutor() - Method in interface ru.yoomoney.tech.dbqueue.api.QueueConsumer
-
Task executor for
ProcessingMode.USE_EXTERNAL_EXECUTOR
mode. - getExtData() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
-
Get the unmodifiable map of extended user-defined parameters for the task: a map where the key is the name of the user-defined column in tasks table, and the value is the value of the user-defined parameter.
- getExtData() - Method in class ru.yoomoney.tech.dbqueue.api.Task
-
Get the map of external user-defined parameters, where the key is the column name in the tasks table.
- getExtData() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
-
Get the map of external user-defined parameters, where the key is the column name in the tasks table.
- getExtFields() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Additional list of column names (
TEXT
type), which are mapping ontoTaskRecord.getExtData()
. - getExtSettings() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
-
Get all additional properties for the queue.
- getFailureSettings() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
-
Settings for task execution strategy in case of failure.
- getFatalCrashTimeout() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
-
Get delay duration when task execution thread sleeps after unexpected error.
- getFixedDelayOrThrow() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
-
Fixed delay.
- getGeometricRatioOrThrow() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
-
Denominator of the geometric progression.
- getId() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
-
Get unique (sequence id) identifier of the task.
- getIdField() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Field with a column name for the id.
- getIdSequence() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation
-
Get id sequence name.
- getInitialDelayOrThrow() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
-
The first term of the progression to compute delays.
- getInstance() - Static method in class ru.yoomoney.tech.dbqueue.api.impl.NoopPayloadTransformer
-
Get payload transformer instance.
- getInstance() - Static method in class ru.yoomoney.tech.dbqueue.config.impl.NoopTaskLifecycleListener
- getInstance() - Static method in class ru.yoomoney.tech.dbqueue.config.impl.NoopThreadLifecycleListener
- getLocation() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfig
-
Get queue location.
- getMillis() - Method in interface ru.yoomoney.tech.dbqueue.internal.processing.MillisTimeProvider
-
Получить время в миллисекундах.
- getMillis() - Method in class ru.yoomoney.tech.dbqueue.internal.processing.MillisTimeProvider.SystemMillisTimeProvider
- getName() - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
- getName() - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
- getName() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
- getName() - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
- getName() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
- getNextProcessAt() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
-
Get date and time of the next task execution.
- getNextProcessAtField() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Field with a column name for task processing date and time (task will be processed after this date).
- getNoTaskTimeout() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
-
Get delay duration between picking tasks from the queue if there are no task for processing.
- getPayload() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
-
Get task payload
- getPayload() - Method in class ru.yoomoney.tech.dbqueue.api.Task
-
Get typed task payload.
- getPayload() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
-
Get raw task payload.
- getPayloadField() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Field with a column name for task payload.
- getPayloadOrThrow() - Method in class ru.yoomoney.tech.dbqueue.api.Task
-
Get typed task payload or throw IllegalArgumentException if not present.
- getPayloadTransformer() - Method in class ru.yoomoney.tech.dbqueue.api.impl.MonitoringQueueProducer
- getPayloadTransformer() - Method in class ru.yoomoney.tech.dbqueue.api.impl.ShardingQueueProducer
- getPayloadTransformer() - Method in interface ru.yoomoney.tech.dbqueue.api.QueueConsumer
-
Get task payload transformer, which transform the task's String payload into the type of the task
- getPayloadTransformer() - Method in interface ru.yoomoney.tech.dbqueue.api.QueueProducer
-
Get task payload transformer, which transform the task's payload into the String
- getPollSettings() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
-
Get task polling settings.
- getProcessingMode() - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
-
Get task processing mode in the queue.
- getProcessingSettings() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
-
Get task processing settings.
- getProperty(String) - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
-
Get string value of additional queue property.
- getQueueConfig() - Method in interface ru.yoomoney.tech.dbqueue.api.QueueConsumer
-
Get queue configuration
- getQueueDao() - Method in interface ru.yoomoney.tech.dbqueue.config.DatabaseAccessLayer
-
Get an instance of database-specific DAO based on database type and table schema.
- getQueueId() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation
-
Get queue identifier.
- getQueueNameField() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Field with a column name for the queue name.
- getQueueTableSchema() - Method in interface ru.yoomoney.tech.dbqueue.config.DatabaseAccessLayer
-
Get queue table schema for that database.
- getReenqueueAttemptField() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Field with a column name for task execution re-enqueue attempts count.
- getReenqueueAttemptsCount() - Method in class ru.yoomoney.tech.dbqueue.api.Task
-
Get number of attempts to postpone (re-enqueue) the task.
- getReenqueueAttemptsCount() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
-
Get number of attempts to postpone (re-enqueue) the task.
- getReenqueueSettings() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
-
Settings for the task postponing strategy when the task should be brought back to the queue.
- getRetryInterval() - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
-
Get retry interval for task execution in case of failure.
- getRetryType() - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
-
Get task execution retry strategy in case of failure.
- getRetryType() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
-
Strategy type, which computes delay to the next processing of the same task.
- getSequentialPlanOrThrow() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
-
Get the sequential plan of delays for task processing.
- getSettings() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfig
-
Get queue settings.
- getShardId() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult
-
Shard identifier of added task
- getShardId() - Method in class ru.yoomoney.tech.dbqueue.api.Task
-
Get the shard identifier from which the task executor took the task.
- getShardId() - Method in class ru.yoomoney.tech.dbqueue.config.QueueShard
-
Get shard identifier.
- getTableName() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation
-
Get queue table name.
- getThis() - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
- getThis() - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
- getThis() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
- getThis() - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
- getThis() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
- getThreadCount() - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
-
Get number of threads for processing tasks in the queue.
- getTotalAttemptField() - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema
-
Field with a column name for task execution total attempts count.
- getTotalAttemptsCount() - Method in class ru.yoomoney.tech.dbqueue.api.Task
-
Get sum of all attempts to execute the task, including all task re-enqueue attempts and all failed attempts.
- getTotalAttemptsCount() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
-
Get sum of all attempts to execute the task, including all task re-enqueue attempts and all failed attempts.
H
- H2 - ru.yoomoney.tech.dbqueue.config.DatabaseDialect
-
H2 in-memory database
- handleResult(TaskRecord, TaskExecutionResult) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.TaskResultHandler
-
Обработать результат выполнения задачи
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.api.Task
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.config.QueueShardId
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfig
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueId
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
- hashCode() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
I
- isPaused() - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Get attribute that all queues were paused with
QueueService.pause()
method. - isPaused() - Method in interface ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop
-
Получить признак, что исполнение кода приостановлено
- isPaused() - Method in class ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WakeupQueueLoop
- isPaused(QueueId) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Get attribute that the specified queue were paused with
QueueService.pause(QueueId)
method. - isShutdown() - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Get attribute that the tasks processing was stopped in all registered queues with
QueueService.shutdown()
. - isShutdown(QueueId) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Get attribute that the tasks processing was stopped in one specific queue with
QueueService.shutdown()
method. - isTerminated() - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Get attribute that all queues finished their execution and all task threads were terminated.
- isTerminated(QueueId) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Get attribute that all the processing task threads were successfully terminated in the specified queue.
L
- LINEAR_BACKOFF - ru.yoomoney.tech.dbqueue.settings.FailRetryType
-
The task is deferred with fixed delay.
- LoggingTaskLifecycleListener - Class in ru.yoomoney.tech.dbqueue.config.impl
-
Task listener with logging support
- LoggingTaskLifecycleListener() - Constructor for class ru.yoomoney.tech.dbqueue.config.impl.LoggingTaskLifecycleListener
-
Constructor
- LoggingThreadLifecycleListener - Class in ru.yoomoney.tech.dbqueue.config.impl
-
Thread listener with logging support
- LoggingThreadLifecycleListener() - Constructor for class ru.yoomoney.tech.dbqueue.config.impl.LoggingThreadLifecycleListener
M
- MANUAL - ru.yoomoney.tech.dbqueue.settings.ReenqueueRetryType
-
The task is deferred by the delay set manually with method
TaskExecutionResult.reenqueue(Duration)
call. - ManualReenqueueRetryStrategy() - Constructor for class ru.yoomoney.tech.dbqueue.internal.processing.ReenqueueRetryStrategy.ManualReenqueueRetryStrategy
- MillisTimeProvider - Interface in ru.yoomoney.tech.dbqueue.internal.processing
-
Поставщик текущего времени в миллисекундах.
- MillisTimeProvider.SystemMillisTimeProvider - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Поставщик системного времени
- MonitoringQueueProducer<PayloadT> - Class in ru.yoomoney.tech.dbqueue.api.impl
-
Wrapper for queue producer with logging and monitoring support
- MonitoringQueueProducer(QueueProducer<PayloadT>, QueueId) - Constructor for class ru.yoomoney.tech.dbqueue.api.impl.MonitoringQueueProducer
-
Constructor
- MonitoringQueueProducer(QueueProducer<PayloadT>, QueueId, BiConsumer<EnqueueResult, Long>) - Constructor for class ru.yoomoney.tech.dbqueue.api.impl.MonitoringQueueProducer
-
Constructor
- MSSQL - ru.yoomoney.tech.dbqueue.config.DatabaseDialect
-
Microsoft SQL Server
N
- NoopPayloadTransformer - Class in ru.yoomoney.tech.dbqueue.api.impl
-
Default payload transformer, which performs no transformation and returns the same string as in the raw payload.
- NoopTaskLifecycleListener - Class in ru.yoomoney.tech.dbqueue.config.impl
-
Empty listener for task processing lifecycle.
- NoopTaskLifecycleListener() - Constructor for class ru.yoomoney.tech.dbqueue.config.impl.NoopTaskLifecycleListener
- NoopThreadLifecycleListener - Class in ru.yoomoney.tech.dbqueue.config.impl
-
Empty listener for task processing thread in the queue.
- NoopThreadLifecycleListener() - Constructor for class ru.yoomoney.tech.dbqueue.config.impl.NoopThreadLifecycleListener
O
- ORACLE_11G - ru.yoomoney.tech.dbqueue.config.DatabaseDialect
-
Oracle 11g
P
- parse() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Try to parse queues configurations.
- pause() - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Pause task processing in all queues.
- pause() - Method in interface ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop
-
Безусловно приостановить исполнение кода
- pause() - Method in class ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WakeupQueueLoop
- pause(QueueId) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Pause task processing in specified queue.
- picked(QueueShardId, QueueLocation, TaskRecord, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeTaskLifecycleListener
- picked(QueueShardId, QueueLocation, TaskRecord, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingTaskLifecycleListener
- picked(QueueShardId, QueueLocation, TaskRecord, long) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopTaskLifecycleListener
- picked(QueueShardId, QueueLocation, TaskRecord, long) - Method in interface ru.yoomoney.tech.dbqueue.config.TaskLifecycleListener
-
Event of task picking from the queue.
- pickTask() - Method in interface ru.yoomoney.tech.dbqueue.dao.QueuePickTaskDao
-
Pick task from a queue
- pickTask() - Method in class ru.yoomoney.tech.dbqueue.internal.processing.TaskPicker
-
Выбрать задачу из очереди
- PollSettings - Class in ru.yoomoney.tech.dbqueue.settings
-
Task polling settings.
- PollSettings.Builder - Class in ru.yoomoney.tech.dbqueue.settings
-
A builder for poll settings.
- POSTGRESQL - ru.yoomoney.tech.dbqueue.config.DatabaseDialect
-
PostgreSQL (version equals or higher than 9.5).
- PROCESSED - ru.yoomoney.tech.dbqueue.internal.processing.QueueProcessingStatus
-
Задача была обрабатана
- ProcessingMode - Enum in ru.yoomoney.tech.dbqueue.settings
-
Strategy for task processing in the queue.
- ProcessingSettings - Class in ru.yoomoney.tech.dbqueue.settings
-
Task processing settings.
- ProcessingSettings.Builder - Class in ru.yoomoney.tech.dbqueue.settings
-
A builder for processing settings.
- ProcessingSettingsParser - Class in ru.yoomoney.tech.dbqueue.settings
-
Parser for
ProcessingSettings
- processTask(QueueConsumer, TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.TaskProcessor
-
Передать выбранную задачу в клиентский код на выполнение и обработать результат
Q
- QueueConfig - Class in ru.yoomoney.tech.dbqueue.settings
-
Queue configuration with database table location and task processing settings.
- QueueConfig(QueueLocation, QueueSettings) - Constructor for class ru.yoomoney.tech.dbqueue.settings.QueueConfig
-
Constructor for queue configuration
- QueueConfigsReader - Class in ru.yoomoney.tech.dbqueue.settings
-
Reads queue configuration from file.
- QueueConfigsReader(List<Path>, String) - Constructor for class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Constructor
- QueueConfigsReader(List<Path>, String, Supplier<ProcessingSettings.Builder>, Supplier<PollSettings.Builder>, Supplier<FailureSettings.Builder>, Supplier<ReenqueueSettings.Builder>) - Constructor for class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Constructor
- QueueConfigsReloader - Class in ru.yoomoney.tech.dbqueue.settings
-
Dynamic reload of queue configuration.
- QueueConfigsReloader(QueueConfigsReader, QueueService) - Constructor for class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReloader
-
Constructor
- QueueConsumer<PayloadT> - Interface in ru.yoomoney.tech.dbqueue.api
-
Task processor for the queue
- QueueDao - Interface in ru.yoomoney.tech.dbqueue.dao
-
Database access object to manage tasks in the queue.
- QueueId - Class in ru.yoomoney.tech.dbqueue.settings
-
Queue identifier.
- QueueId(String) - Constructor for class ru.yoomoney.tech.dbqueue.settings.QueueId
-
Constructor
- QueueLocation - Class in ru.yoomoney.tech.dbqueue.settings
-
Queue location in the database.
- QueueLocation.Builder - Class in ru.yoomoney.tech.dbqueue.settings
-
A builder for class
QueueLocation
. - QueueLoop - Interface in ru.yoomoney.tech.dbqueue.internal.processing
-
Вспомогательный класс, для задания стратегии выполнения задачи в цикле
- QueueLoop.WaitInterrupt - Enum in ru.yoomoney.tech.dbqueue.internal.processing
-
Признак прерывания ожидания
- QueueLoop.WakeupQueueLoop - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Cтратегия выполнения задачи в потоке
- QueuePickTaskDao - Interface in ru.yoomoney.tech.dbqueue.dao
-
Database access object to pick up tasks in the queue.
- QueueProcessingStatus - Enum in ru.yoomoney.tech.dbqueue.internal.processing
-
Тип результата обработки задачи в очереди
- QueueProducer<PayloadT> - Interface in ru.yoomoney.tech.dbqueue.api
-
Task producer for the queue, which adds a new task into the queue.
- QueueRunner - Interface in ru.yoomoney.tech.dbqueue.internal.runner
-
Интерфейс обработчика пула задач очереди
- QueueRunner.Factory - Class in ru.yoomoney.tech.dbqueue.internal.runner
-
Фабрика исполнителей задач в очереди
- QueueService - Class in ru.yoomoney.tech.dbqueue.config
-
A service for managing start, pause and shutdown of task processors.
- QueueService(List<QueueShard<?>>, ThreadLifecycleListener, TaskLifecycleListener) - Constructor for class ru.yoomoney.tech.dbqueue.config.QueueService
- QueueSettings - Class in ru.yoomoney.tech.dbqueue.settings
-
Queue settings
- QueueSettings.Builder - Class in ru.yoomoney.tech.dbqueue.settings
-
A builder for queue settings.
- QueueShard<DatabaseAccessLayerT extends DatabaseAccessLayer> - Class in ru.yoomoney.tech.dbqueue.config
-
Properties for connection to a database shard.
- QueueShard(QueueShardId, DatabaseAccessLayerT) - Constructor for class ru.yoomoney.tech.dbqueue.config.QueueShard
-
Constructor
- QueueShardId - Class in ru.yoomoney.tech.dbqueue.config
-
Storage for shard information.
- QueueShardId(String) - Constructor for class ru.yoomoney.tech.dbqueue.config.QueueShardId
-
Constructor
- QueueShardRouter<PayloadT,DatabaseAccessLayerT extends DatabaseAccessLayer> - Interface in ru.yoomoney.tech.dbqueue.api
-
Dispatcher for sharding support.
- QueueTableSchema - Class in ru.yoomoney.tech.dbqueue.config
-
Scheme for column names of queue table in the database.
- QueueTableSchema.Builder - Class in ru.yoomoney.tech.dbqueue.config
-
Builder for
QueueTableSchema
class. - QueueTaskPoller - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Цикл обработки задачи в очереди.
- QueueTaskPoller(ThreadLifecycleListener, MillisTimeProvider) - Constructor for class ru.yoomoney.tech.dbqueue.internal.processing.QueueTaskPoller
-
Конструктор
R
- reenqueue() - Static method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
-
Instruction to re-enqueue the task using the
re-enqueue strategy
established in the queue configuration. - reenqueue(Duration) - Static method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
-
Instruction to re-enqueue the task with determined execution delay.
- reenqueue(QueueLocation, long, Duration) - Method in interface ru.yoomoney.tech.dbqueue.dao.QueueDao
-
Postpone task processing for given time period (current date and time plus execution delay).
- REENQUEUE - ru.yoomoney.tech.dbqueue.api.TaskExecutionResult.Type
-
Postpone (re-enqueue) the task, so that the task will be executed again
- ReenqueueRetryStrategy - Interface in ru.yoomoney.tech.dbqueue.internal.processing
-
Стратегия по вычислению задержки перед следующим выполнением задачи в случае, если задачу требуется вернуть в очередь.
- ReenqueueRetryStrategy.ArithmeticReenqueueRetryStrategy - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Стратегия, которая возвращает задержку на основании арифметической прогрессии, заданной с помощью ее первого члена и разности.
- ReenqueueRetryStrategy.Factory - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Фабрика для создания стратегии повтора задача, в зависимости от настроек
- ReenqueueRetryStrategy.FixedDelayReenqueueRetryStrategy - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Стратегия, которая возвращает фиксированную задержку для любого выполнения задачи.
- ReenqueueRetryStrategy.GeometricReenqueueRetryStrategy - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Стратегия, которая возвращает задержку на основании геометрической прогрессии, заданной с помощью ее первого члена и целочисленного знаменателя.
- ReenqueueRetryStrategy.ManualReenqueueRetryStrategy - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Стратегия, которая не вычисляет задержку.
- ReenqueueRetryStrategy.SequentialReenqueueRetryStrategy - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Стратегия, которая возвращает задержку на основании некоторой конечной последовательности.
- ReenqueueRetryType - Enum in ru.yoomoney.tech.dbqueue.settings
-
Type of the strategy, which computes the delay before the next task execution if the task has to be brought back
to the queue
. - ReenqueueSettings - Class in ru.yoomoney.tech.dbqueue.settings
-
Settings for the task postponing strategy when the task should be brought back to the queue.
- ReenqueueSettings.Builder - Class in ru.yoomoney.tech.dbqueue.settings
-
A builder for creating new instances of
ReenqueueSettings
. - registerQueue(QueueConsumer<PayloadT>) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Register new task processor of given payload type.
- resolveShard(EnqueueParams<PayloadT>) - Method in class ru.yoomoney.tech.dbqueue.api.impl.SingleQueueShardRouter
- resolveShard(EnqueueParams<PayloadT>) - Method in interface ru.yoomoney.tech.dbqueue.api.QueueShardRouter
-
Get designated shard for task parameters
- ru.yoomoney.tech.dbqueue.api - package ru.yoomoney.tech.dbqueue.api
- ru.yoomoney.tech.dbqueue.api.impl - package ru.yoomoney.tech.dbqueue.api.impl
- ru.yoomoney.tech.dbqueue.config - package ru.yoomoney.tech.dbqueue.config
- ru.yoomoney.tech.dbqueue.config.impl - package ru.yoomoney.tech.dbqueue.config.impl
- ru.yoomoney.tech.dbqueue.dao - package ru.yoomoney.tech.dbqueue.dao
- ru.yoomoney.tech.dbqueue.internal.processing - package ru.yoomoney.tech.dbqueue.internal.processing
- ru.yoomoney.tech.dbqueue.internal.runner - package ru.yoomoney.tech.dbqueue.internal.runner
- ru.yoomoney.tech.dbqueue.settings - package ru.yoomoney.tech.dbqueue.settings
- runQueue(QueueConsumer) - Method in class ru.yoomoney.tech.dbqueue.internal.runner.BaseQueueRunner
- runQueue(QueueConsumer) - Method in interface ru.yoomoney.tech.dbqueue.internal.runner.QueueRunner
-
Единократно обработать заданную очередь
S
- SEPARATE_TRANSACTIONS - ru.yoomoney.tech.dbqueue.settings.ProcessingMode
-
Task will be processed at least once.
- SEQUENTIAL - ru.yoomoney.tech.dbqueue.settings.ReenqueueRetryType
-
The task is deferred by the delay set with the sequence of delays.
- SETTING_ADDITIONAL - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
QueueSettings.getExtSettings()
- SETTING_BETWEEN_TASK_TIMEOUT - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
PollSettings.getBetweenTaskTimeout()
- SETTING_FATAL_CRASH_TIMEOUT - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
PollSettings.getFatalCrashTimeout()
- SETTING_ID_SEQUENCE - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
QueueLocation.getIdSequence()
- SETTING_NO_TASK_TIMEOUT - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
PollSettings.getNoTaskTimeout()
- SETTING_PROCESSING_MODE - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ProcessingSettings.getProcessingMode()
- SETTING_REENQUEUE_RETRY_DELAY - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueSettings.getFixedDelayOrThrow()
- SETTING_REENQUEUE_RETRY_INITIAL_DELAY - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueSettings.getInitialDelayOrThrow()
- SETTING_REENQUEUE_RETRY_PLAN - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueSettings.getSequentialPlanOrThrow()
- SETTING_REENQUEUE_RETRY_RATIO - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueSettings.getGeometricRatioOrThrow()
- SETTING_REENQUEUE_RETRY_STEP - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueSettings.getArithmeticStepOrThrow()
- SETTING_REENQUEUE_RETRY_TYPE - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueSettings.getRetryType()
- SETTING_RETRY_INTERVAL - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
FailureSettings.getRetryInterval()
- SETTING_RETRY_TYPE - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
FailureSettings.getRetryType()
- SETTING_TABLE - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
QueueLocation.getTableName()
- SETTING_THREAD_COUNT - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ProcessingSettings.getThreadCount()
- ShardingQueueProducer<PayloadTaskT,DatabaseAccessLayerT extends DatabaseAccessLayer> - Class in ru.yoomoney.tech.dbqueue.api.impl
-
Wrapper for queue producer wrapper with sharding support.
- ShardingQueueProducer(QueueConfig, TaskPayloadTransformer<PayloadTaskT>, QueueShardRouter<PayloadTaskT, DatabaseAccessLayerT>) - Constructor for class ru.yoomoney.tech.dbqueue.api.impl.ShardingQueueProducer
-
Constructor
- shutdown() - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Stop tasks processing in all queues registered in the service, semantic is the same as for
ExecutorService.shutdownNow()
. - shutdown(QueueId) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Stop tasks processing in one given queue, semantic is the same as for
ExecutorService.shutdownNow()
. - SingleQueueShardRouter<PayloadT,DatabaseAccessLayerT extends DatabaseAccessLayer> - Class in ru.yoomoney.tech.dbqueue.api.impl
-
Shard router without sharding.
- SingleQueueShardRouter(QueueShard<DatabaseAccessLayerT>) - Constructor for class ru.yoomoney.tech.dbqueue.api.impl.SingleQueueShardRouter
-
Constructor
- SKIPPED - ru.yoomoney.tech.dbqueue.internal.processing.QueueProcessingStatus
-
Задача не была найдена и обработка не состоялась
- start() - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Start tasks processing in all queues registered in the service.
- start() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReloader
-
Starts automatic reload of queue configuration
- start(QueueLoop, QueueShardId, QueueConsumer, QueueRunner) - Method in class ru.yoomoney.tech.dbqueue.internal.processing.QueueTaskPoller
-
Запустить цикл обработки задач в очереди
- start(QueueId) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Start tasks processing in one given queue.
- started(QueueShardId, QueueLocation) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeThreadLifecycleListener
- started(QueueShardId, QueueLocation) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingThreadLifecycleListener
- started(QueueShardId, QueueLocation) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopThreadLifecycleListener
- started(QueueShardId, QueueLocation) - Method in interface ru.yoomoney.tech.dbqueue.config.ThreadLifecycleListener
-
Start of the task processing in the queue.
- started(QueueShardId, QueueLocation, TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.config.impl.CompositeTaskLifecycleListener
- started(QueueShardId, QueueLocation, TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.config.impl.LoggingTaskLifecycleListener
- started(QueueShardId, QueueLocation, TaskRecord) - Method in class ru.yoomoney.tech.dbqueue.config.impl.NoopTaskLifecycleListener
- started(QueueShardId, QueueLocation, TaskRecord) - Method in interface ru.yoomoney.tech.dbqueue.config.TaskLifecycleListener
-
The start event of task processing.
- stop() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReloader
-
Stops automatic reload of queue configuration
- SystemMillisTimeProvider() - Constructor for class ru.yoomoney.tech.dbqueue.internal.processing.MillisTimeProvider.SystemMillisTimeProvider
T
- Task<PayloadT> - Class in ru.yoomoney.tech.dbqueue.api
-
Typed task wrapper with parameters, which is supplied to the QueueConsumer task processor
- Task.Builder<PayloadBuilderT> - Class in ru.yoomoney.tech.dbqueue.api
-
Builder for the
Task
wrapper. - TaskExecutionResult - Class in ru.yoomoney.tech.dbqueue.api
-
The action, which should be performed after the task processing.
- TaskExecutionResult.Type - Enum in ru.yoomoney.tech.dbqueue.api
-
Action performed after task processing
- TaskLifecycleListener - Interface in ru.yoomoney.tech.dbqueue.config
-
Listener for task processing lifecycle.
- TaskPayloadTransformer<PayloadT> - Interface in ru.yoomoney.tech.dbqueue.api
-
Marshaller and unmarshaller for the payload in the task
- TaskPicker - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Класс, обеспечивающий выборку задачи из очереди
- TaskPicker(QueueShard<?>, QueueLocation, TaskLifecycleListener, MillisTimeProvider, QueuePickTaskDao) - Constructor for class ru.yoomoney.tech.dbqueue.internal.processing.TaskPicker
-
Constructor
- TaskProcessor - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Обработчик выбранной задачи
- TaskProcessor(QueueShard<?>, TaskLifecycleListener, MillisTimeProvider, TaskResultHandler) - Constructor for class ru.yoomoney.tech.dbqueue.internal.processing.TaskProcessor
-
Конструктор
- TaskRecord - Class in ru.yoomoney.tech.dbqueue.api
-
Raw database record with task parameters and payload
- TaskRecord.Builder - Class in ru.yoomoney.tech.dbqueue.api
-
Builder for the
TaskRecord
class - TaskResultHandler - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Обработчик результат выполенения задачи
- TaskResultHandler(QueueLocation, QueueShard<?>, ReenqueueSettings) - Constructor for class ru.yoomoney.tech.dbqueue.internal.processing.TaskResultHandler
-
Конструктор
- ThreadLifecycleListener - Interface in ru.yoomoney.tech.dbqueue.config
-
Listener for task processing thread in the queue.
- TimeLimiter - Class in ru.yoomoney.tech.dbqueue.internal.processing
-
Класс, для ограничения времени нескольких действий в заданный таймаут
- TimeLimiter(MillisTimeProvider, Duration) - Constructor for class ru.yoomoney.tech.dbqueue.internal.processing.TimeLimiter
- toObject(String) - Method in class ru.yoomoney.tech.dbqueue.api.impl.NoopPayloadTransformer
- toObject(String) - Method in interface ru.yoomoney.tech.dbqueue.api.TaskPayloadTransformer
-
Unmarshall the string payload from the task into the object with task data
- toString() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
- toString() - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult
- toString() - Method in class ru.yoomoney.tech.dbqueue.api.Task
- toString() - Method in class ru.yoomoney.tech.dbqueue.api.TaskExecutionResult
- toString() - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord
- toString() - Method in class ru.yoomoney.tech.dbqueue.config.QueueShardId
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueConfig
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueId
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings
- toString() - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings
- transact(Runnable) - Method in interface ru.yoomoney.tech.dbqueue.config.DatabaseAccessLayer
-
Perform an operation in transaction
- transact(Supplier<ResultT>) - Method in interface ru.yoomoney.tech.dbqueue.config.DatabaseAccessLayer
-
Perform an operation in transaction
U
- unpause() - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Continue task processing in all queues.
- unpause() - Method in interface ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop
-
Безусловно продолжить исполнение кода
- unpause() - Method in class ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WakeupQueueLoop
- unpause(QueueId) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Continue task processing in specified queue.
- updateQueueConfigs(Collection<QueueConfig>) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Update queue configurations.
- USE_EXTERNAL_EXECUTOR - ru.yoomoney.tech.dbqueue.settings.ProcessingMode
-
Task will be processed at least ones, asynchronously in given executor
QueueConsumer.getExecutor()
.
V
- VALUE_PROCESSING_MODE_SEPARATE_TRANSACTIONS - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ProcessingMode.SEPARATE_TRANSACTIONS
- VALUE_PROCESSING_MODE_USE_EXTERNAL_EXECUTOR - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ProcessingMode.USE_EXTERNAL_EXECUTOR
- VALUE_PROCESSING_MODE_WRAP_IN_TRANSACTION - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ProcessingMode.WRAP_IN_TRANSACTION
- VALUE_REENQUEUE_RETRY_TYPE_ARITHMETIC - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueRetryType.ARITHMETIC
- VALUE_REENQUEUE_RETRY_TYPE_FIXED - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueRetryType.FIXED
- VALUE_REENQUEUE_RETRY_TYPE_GEOMETRIC - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueRetryType.GEOMETRIC
- VALUE_REENQUEUE_RETRY_TYPE_MANUAL - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueRetryType.MANUAL
- VALUE_REENQUEUE_RETRY_TYPE_SEQUENTIAL - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
ReenqueueRetryType.SEQUENTIAL
- VALUE_TASK_RETRY_TYPE_ARITHMETIC - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
FailRetryType.ARITHMETIC_BACKOFF
- VALUE_TASK_RETRY_TYPE_GEOMETRIC - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
FailRetryType.GEOMETRIC_BACKOFF
- VALUE_TASK_RETRY_TYPE_LINEAR - Static variable in class ru.yoomoney.tech.dbqueue.settings.QueueConfigsReader
-
Representation of
FailRetryType.LINEAR_BACKOFF
- valueOf(String) - Static method in enum ru.yoomoney.tech.dbqueue.api.TaskExecutionResult.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum ru.yoomoney.tech.dbqueue.config.DatabaseDialect
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WaitInterrupt
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum ru.yoomoney.tech.dbqueue.internal.processing.QueueProcessingStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum ru.yoomoney.tech.dbqueue.settings.FailRetryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum ru.yoomoney.tech.dbqueue.settings.ProcessingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum ru.yoomoney.tech.dbqueue.settings.ReenqueueRetryType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum ru.yoomoney.tech.dbqueue.api.TaskExecutionResult.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum ru.yoomoney.tech.dbqueue.config.DatabaseDialect
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WaitInterrupt
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum ru.yoomoney.tech.dbqueue.internal.processing.QueueProcessingStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum ru.yoomoney.tech.dbqueue.settings.FailRetryType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum ru.yoomoney.tech.dbqueue.settings.ProcessingMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum ru.yoomoney.tech.dbqueue.settings.ReenqueueRetryType
-
Returns an array containing the constants of this enum type, in the order they are declared.
W
- wakeup(QueueId, QueueShardId) - Method in class ru.yoomoney.tech.dbqueue.config.QueueService
-
Force continue task processing in specified queue by given shard identifier.
- WakeupQueueLoop() - Constructor for class ru.yoomoney.tech.dbqueue.internal.processing.QueueLoop.WakeupQueueLoop
- withArithmeticStep(Duration) - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings.Builder
- withAttemptField(String) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withAttemptsCount(long) - Method in class ru.yoomoney.tech.dbqueue.api.Task.Builder
- withAttemptsCount(long) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- withBetweenTaskTimeout(Duration) - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings.Builder
-
Set delay duration between picking tasks from the queue after the task was processed.
- withCreatedAt(ZonedDateTime) - Method in class ru.yoomoney.tech.dbqueue.api.Task.Builder
- withCreatedAt(ZonedDateTime) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- withCreatedAtField(String) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withEnqueueId(Long) - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult.Builder
-
Set identifier (sequence id) of added task
- withExecutionDelay(Duration) - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
-
Add an execution delay for the task.
- withExtData(String, String) - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
-
Add the external user parameter for the task.
- withExtData(Map<String, String>) - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
-
Update the task parameters with the map of external user-defined parameters, a map where the key is the name of the user-defined column in tasks table, and the value is the value of the user-defined parameter.
- withExtData(Map<String, String>) - Method in class ru.yoomoney.tech.dbqueue.api.Task.Builder
- withExtData(Map<String, String>) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- withExtFields(List<String>) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withExtSettings(ExtSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings.Builder
-
Set the map of additional properties for the queue.
- withFailureSettings(FailureSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings.Builder
-
Sets settings for task execution strategy in case of failure.
- withFatalCrashTimeout(Duration) - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings.Builder
-
Set delay duration after unexpected error.
- withFixedDelay(Duration) - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings.Builder
- withGeometricRatio(Long) - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings.Builder
- withId(long) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- withIdField(String) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withIdSequence(String) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation.Builder
-
Set id sequence name.
- withInitialDelay(Duration) - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings.Builder
- withNextProcessAt(ZonedDateTime) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- withNextProcessAtField(String) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withNoTaskTimeout(Duration) - Method in class ru.yoomoney.tech.dbqueue.settings.PollSettings.Builder
-
Set delay duration between picking tasks from the queue if there are no task for processing.
- withPayload(String) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- withPayload(PayloadBuilderT) - Method in class ru.yoomoney.tech.dbqueue.api.Task.Builder
- withPayload(PayloadT) - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueParams
-
Add a typed payload to the task parameters
- withPayloadField(String) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withPollSettings(PollSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings.Builder
-
Sets task polling settings
- withProcessingMode(ProcessingMode) - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings.Builder
-
Set task processing mode in the queue.
- withProcessingSettings(ProcessingSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings.Builder
-
Sets task processing settings.
- withQueueId(QueueId) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation.Builder
-
Set queue identifier.
- withQueueNameField(String) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withReenqueueAttemptField(String) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withReenqueueAttemptsCount(long) - Method in class ru.yoomoney.tech.dbqueue.api.Task.Builder
- withReenqueueAttemptsCount(long) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- withReenqueueSettings(ReenqueueSettings) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueSettings.Builder
-
Set Settings for the task postponing strategy when the task should be brought back to the queue.
- withRetryInterval(Duration) - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings.Builder
-
Set retry interval for task execution in case of failure.
- withRetryType(FailRetryType) - Method in class ru.yoomoney.tech.dbqueue.settings.FailureSettings.Builder
-
Set task execution retry strategy in case of failure.
- withRetryType(ReenqueueRetryType) - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings.Builder
- withSequentialPlan(List<Duration>) - Method in class ru.yoomoney.tech.dbqueue.settings.ReenqueueSettings.Builder
- withSettings(Map<String, String>) - Method in class ru.yoomoney.tech.dbqueue.settings.ExtSettings.Builder
- withShardId(QueueShardId) - Method in class ru.yoomoney.tech.dbqueue.api.EnqueueResult.Builder
-
Set shard identifier of added task
- withTableName(String) - Method in class ru.yoomoney.tech.dbqueue.settings.QueueLocation.Builder
-
Set table name for queue tasks.
- withThreadCount(Integer) - Method in class ru.yoomoney.tech.dbqueue.settings.ProcessingSettings.Builder
-
Set number of threads for processing tasks in the queue.
- withTotalAttemptField(String) - Method in class ru.yoomoney.tech.dbqueue.config.QueueTableSchema.Builder
- withTotalAttemptsCount(long) - Method in class ru.yoomoney.tech.dbqueue.api.Task.Builder
- withTotalAttemptsCount(long) - Method in class ru.yoomoney.tech.dbqueue.api.TaskRecord.Builder
- WRAP_IN_TRANSACTION - ru.yoomoney.tech.dbqueue.settings.ProcessingMode
-
Task processing wrapped into separate database transaction.
All Classes All Packages