Index
All Classes and Interfaces|All Packages
A
- addConsumer(String, ConsumerWorker<InputT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a consumer task to the pipeline.
- addConsumer(String, ConsumerWorkerFactory<InputT, MetricsT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a consumer task to the pipeline.
- addConsumer(String, MeasuredConsumerWorker<InputT, MetricsT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a consumer task to the pipeline.
- addLifecycleListener(Pipeline.LifecycleListener) - Method in class io.aleph0.yap.core.build.PipelineBuilder
- addLifecycleListener(Pipeline.LifecycleListener) - Method in interface io.aleph0.yap.core.Pipeline
- addLifecycleListener(Pipeline.LifecycleListener) - Method in class io.aleph0.yap.core.pipeline.DefaultPipeline
- addLifecycleListener(Pipeline.LifecycleListener) - Method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- addLifecycleListener(PipelineManager.LifecycleListener) - Method in class io.aleph0.yap.core.pipeline.PipelineManager
- addLifecycleListener(TaskManager.LifecycleListener) - Method in class io.aleph0.yap.core.task.TaskManager
- addProcessor(String, ProcessorWorker<InputT, OutputT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a processor task to the pipeline.
- addProcessor(String, MeasuredProcessorWorker<InputT, OutputT, MetricsT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a processor task to the pipeline.
- addProcessor(String, ProcessorWorkerFactory<InputT, OutputT, MetricsT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a processor task to the pipeline.
- addProducer(String, ProducerWorker<OutputT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a producer task to the pipeline.
- addProducer(String, MeasuredProducerWorker<OutputT, MetricsT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a producer task to the pipeline.
- addProducer(String, ProducerWorkerFactory<OutputT, MetricsT>) - Method in class io.aleph0.yap.core.build.PipelineBuilder
-
Add a producer task to the pipeline.
- addSubscriber(ConsumerTaskBuilder<? super OutputT, ?>) - Method in class io.aleph0.yap.core.build.ProcessorTaskBuilder
- addSubscriber(ConsumerTaskBuilder<? super OutputT, ?>) - Method in class io.aleph0.yap.core.build.ProducerTaskBuilder
- addSubscriber(ProcessorTaskBuilder<? super OutputT, NextT, ?>) - Method in class io.aleph0.yap.core.build.ProcessorTaskBuilder
- addSubscriber(ProcessorTaskBuilder<? super OutputT, NextT, ?>) - Method in class io.aleph0.yap.core.build.ProducerTaskBuilder
- addWrapper(PipelineWrapper) - Method in class io.aleph0.yap.core.build.PipelineBuilder
- await() - Method in interface io.aleph0.yap.core.Pipeline
- await() - Method in class io.aleph0.yap.core.pipeline.DefaultPipeline
- await() - Method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
B
- bind(Channel.Binding<T>) - Method in interface io.aleph0.yap.core.transport.Channel
- bind(Channel.Binding<T>) - Method in class io.aleph0.yap.core.transport.channel.DefaultChannel
- blocks() - Method in record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Returns the value of the
blocksrecord component. - build() - Method in class io.aleph0.yap.core.build.PipelineBuilder
- build(Queue<InputT>) - Method in class io.aleph0.yap.core.task.DefaultConsumerTaskController.Builder
- build(Queue<InputT>) - Method in interface io.aleph0.yap.core.task.TaskController.ConsumerTaskControllerBuilder
- build(Queue<InputT>, Topic<OutputT>) - Method in class io.aleph0.yap.core.task.DefaultProcessorTaskController.Builder
- build(Queue<InputT>, Topic<OutputT>) - Method in interface io.aleph0.yap.core.task.TaskController.ProcessorTaskControllerBuilder
- build(Topic<OutputT>) - Method in class io.aleph0.yap.core.task.DefaultProducerTaskController.Builder
- build(Topic<OutputT>) - Method in interface io.aleph0.yap.core.task.TaskController.ProducerTaskControllerBuilder
- build(List<Channel<T>>) - Method in interface io.aleph0.yap.core.build.QueueBuilder
- build(List<Channel<T>>) - Method in interface io.aleph0.yap.core.build.TopicBuilder
- build(List<Channel<T>>) - Method in class io.aleph0.yap.core.transport.queue.DefaultQueue.Builder
- build(List<Channel<T>>) - Method in class io.aleph0.yap.core.transport.topic.DefaultTopic.Builder
- build(Map<String, Set<String>>) - Method in interface io.aleph0.yap.core.build.PipelineControllerBuilder
- build(Map<String, Set<String>>) - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController.Builder
- buildAndStart() - Method in class io.aleph0.yap.core.build.PipelineBuilder
- buildAndStartAsCompletableFuture() - Method in class io.aleph0.yap.core.build.PipelineBuilder
- buildAndStartAsFuture() - Method in class io.aleph0.yap.core.build.PipelineBuilder
- builder() - Static method in interface io.aleph0.yap.core.Pipeline
- builder() - Static method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- builder() - Static method in class io.aleph0.yap.core.task.DefaultConsumerTaskController
- builder() - Static method in class io.aleph0.yap.core.task.DefaultProcessorTaskController
- builder() - Static method in class io.aleph0.yap.core.task.DefaultProducerTaskController
- builder() - Static method in class io.aleph0.yap.core.transport.queue.DefaultQueue
- builder() - Static method in class io.aleph0.yap.core.transport.topic.DefaultTopic
- Builder() - Constructor for class io.aleph0.yap.core.pipeline.DefaultPipelineController.Builder
- Builder() - Constructor for class io.aleph0.yap.core.task.DefaultConsumerTaskController.Builder
- Builder() - Constructor for class io.aleph0.yap.core.task.DefaultProcessorTaskController.Builder
- Builder() - Constructor for class io.aleph0.yap.core.task.DefaultProducerTaskController.Builder
- Builder() - Constructor for class io.aleph0.yap.core.transport.queue.DefaultQueue.Builder
- Builder() - Constructor for class io.aleph0.yap.core.transport.topic.DefaultTopic.Builder
C
- cancel() - Static method in interface io.aleph0.yap.core.pipeline.action.PipelineAction
- cancel() - Method in interface io.aleph0.yap.core.Pipeline
- cancel() - Method in class io.aleph0.yap.core.pipeline.DefaultPipeline
- cancel() - Method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- CANCELED - Enum constant in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
The pipeline is done processing and has shut down.
- CANCELED - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
The task is done processing and has shut down.
- CANCELED - Enum constant in enum class io.aleph0.yap.core.task.TaskManager.TaskState
- CANCELING - Enum constant in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
The user has
requested cancellationand the pipeline is in the process of shutting down. - CANCELING - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
The user has
requested cancellationand the task is in the process of shutting down. - CANCELLED - Enum constant in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
- CancelPipelineAction - Record Class in io.aleph0.yap.core.pipeline.action
- CancelPipelineAction() - Constructor for record class io.aleph0.yap.core.pipeline.action.CancelPipelineAction
-
Creates an instance of a
CancelPipelineActionrecord class. - cancelTask(String) - Static method in interface io.aleph0.yap.core.pipeline.action.PipelineAction
- CancelTaskAction - Record Class in io.aleph0.yap.core.task.action
- CancelTaskAction() - Constructor for record class io.aleph0.yap.core.task.action.CancelTaskAction
-
Creates an instance of a
CancelTaskActionrecord class. - CancelTaskPipelineAction - Record Class in io.aleph0.yap.core.pipeline.action
- CancelTaskPipelineAction(String) - Constructor for record class io.aleph0.yap.core.pipeline.action.CancelTaskPipelineAction
-
Creates an instance of a
CancelTaskPipelineActionrecord class. - cause() - Method in record class io.aleph0.yap.core.pipeline.action.FailPipelineAction
-
Returns the value of the
causerecord component. - cause() - Method in record class io.aleph0.yap.core.task.action.FailTaskAction
-
Returns the value of the
causerecord component. - Channel<T> - Interface in io.aleph0.yap.core.transport
- Channel.Binding<T> - Interface in io.aleph0.yap.core.transport
-
A destination for messages.
- checkMetrics() - Method in interface io.aleph0.yap.core.Measureable
-
Non-destructive check of the metrics.
- checkMetrics() - Method in class io.aleph0.yap.core.pipeline.DefaultPipeline
- checkMetrics() - Method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- checkMetrics() - Method in class io.aleph0.yap.core.pipeline.PipelineManager
- checkMetrics() - Method in class io.aleph0.yap.core.task.TaskManager
- checkMetrics() - Method in interface io.aleph0.yap.core.task.TaskManager.WorkerBodyFactory
- checkMetrics() - Method in class io.aleph0.yap.core.transport.queue.DefaultQueue
- checkMetrics() - Method in class io.aleph0.yap.core.transport.topic.DefaultTopic
- checkMetrics() - Method in class io.aleph0.yap.core.worker.DefaultConsumerWorkerFactory
- checkMetrics() - Method in class io.aleph0.yap.core.worker.DefaultProcessorWorkerFactory
- checkMetrics() - Method in class io.aleph0.yap.core.worker.DefaultProducerWorkerFactory
- checkMetrics() - Method in class io.aleph0.yap.core.worker.SingletonConsumerWorkerFactory
- checkMetrics() - Method in class io.aleph0.yap.core.worker.SingletonProcessorWorkerFactory
- checkMetrics() - Method in class io.aleph0.yap.core.worker.SingletonProducerWorkerFactory
- close() - Method in interface io.aleph0.yap.core.transport.Channel.Binding
-
Closes the binding.
- close() - Method in interface io.aleph0.yap.core.transport.Channel
- close() - Method in class io.aleph0.yap.core.transport.channel.DefaultChannel
- close() - Method in interface io.aleph0.yap.core.transport.Topic
- close() - Method in class io.aleph0.yap.core.transport.topic.DefaultTopic
- commencements() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
commencementsrecord component. - COMPLETED - Enum constant in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
The pipeline is done processing and has shut down.
- COMPLETED - Enum constant in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
- COMPLETED - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
The task is done processing and has shut down.
- COMPLETING - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
The task is done processing and is in the process of shutting down.
- completions() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
completionsrecord component. - consume(Source<InputT>) - Method in interface io.aleph0.yap.core.ConsumerWorker
- consumed() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
consumedrecord component. - consumed() - Method in record class io.aleph0.yap.core.transport.Queue.Metrics
-
Returns the value of the
consumedrecord component. - ConsumerTaskBuilder<InputT,
MetricsT> - Class in io.aleph0.yap.core.build - ConsumerWorker<InputT> - Interface in io.aleph0.yap.core
-
A worker that consumes inputs via a
source. - ConsumerWorkerFactory<InputT,
MetricsT> - Interface in io.aleph0.yap.core.worker
D
- DEFAULT_PERIOD - Static variable in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- DefaultChannel<T> - Class in io.aleph0.yap.core.transport.channel
- DefaultChannel() - Constructor for class io.aleph0.yap.core.transport.channel.DefaultChannel
- DefaultConsumerTaskController<InputT> - Class in io.aleph0.yap.core.task
- DefaultConsumerTaskController(int, Duration, Queue<InputT>) - Constructor for class io.aleph0.yap.core.task.DefaultConsumerTaskController
- DefaultConsumerTaskController.Builder<InputT> - Class in io.aleph0.yap.core.task
- DefaultConsumerWorkerFactory<InputT,
MetricsT> - Class in io.aleph0.yap.core.worker -
A
ConsumerWorkerFactorythat creates and manages multipleMeasuredConsumerWorkers and tracks their metrics. - DefaultConsumerWorkerFactory(MeasuredConsumerWorker<InputT, MetricsT>, BinaryOperator<MetricsT>) - Constructor for class io.aleph0.yap.core.worker.DefaultConsumerWorkerFactory
- DefaultPipeline - Class in io.aleph0.yap.core.pipeline
- DefaultPipeline(PipelineManager) - Constructor for class io.aleph0.yap.core.pipeline.DefaultPipeline
- DefaultPipelineController - Class in io.aleph0.yap.core.pipeline
- DefaultPipelineController(Map<String, Set<String>>, Duration) - Constructor for class io.aleph0.yap.core.pipeline.DefaultPipelineController
-
Create a new pipeline controller.
- DefaultPipelineController.Builder - Class in io.aleph0.yap.core.pipeline
- DefaultPipelineController.PipelineState - Enum Class in io.aleph0.yap.core.pipeline
-
The internal state of a pipeline.
- DefaultProcessorTaskController<InputT,
OutputT> - Class in io.aleph0.yap.core.task - DefaultProcessorTaskController(int, Duration, Queue<InputT>, Topic<OutputT>) - Constructor for class io.aleph0.yap.core.task.DefaultProcessorTaskController
- DefaultProcessorTaskController.Builder<InputT,
OutputT> - Class in io.aleph0.yap.core.task - DefaultProcessorWorkerFactory<InputT,
OutputT, - Class in io.aleph0.yap.core.workerMetricsT> -
A
ProcessorWorkerFactorythat creates and manages multipleMeasuredProcessorWorkers and tracks their metrics. - DefaultProcessorWorkerFactory(Supplier<MeasuredProcessorWorker<InputT, OutputT, MetricsT>>, BinaryOperator<MetricsT>) - Constructor for class io.aleph0.yap.core.worker.DefaultProcessorWorkerFactory
- DefaultProducerTaskController<OutputT> - Class in io.aleph0.yap.core.task
- DefaultProducerTaskController(int, Duration, Topic<OutputT>) - Constructor for class io.aleph0.yap.core.task.DefaultProducerTaskController
- DefaultProducerTaskController.Builder<OutputT> - Class in io.aleph0.yap.core.task
- DefaultProducerWorkerFactory<OutputT,
MetricsT> - Class in io.aleph0.yap.core.worker -
A
ProducerWorkerFactorythat creates and manages multipleMeasuredProducerWorkers and tracks their metrics. - DefaultProducerWorkerFactory(Supplier<MeasuredProducerWorker<OutputT, MetricsT>>, BinaryOperator<MetricsT>) - Constructor for class io.aleph0.yap.core.worker.DefaultProducerWorkerFactory
- DefaultQueue<T> - Class in io.aleph0.yap.core.transport.queue
- DefaultQueue(int, List<Channel<T>>) - Constructor for class io.aleph0.yap.core.transport.queue.DefaultQueue
- DefaultQueue.Builder<T> - Class in io.aleph0.yap.core.transport.queue
- DefaultQueue.Metrics - Record Class in io.aleph0.yap.core.transport.queue
- DefaultTaskController<InputT,
OutputT> - Class in io.aleph0.yap.core.task - DefaultTaskController(int, Duration, Queue<InputT>, Topic<OutputT>) - Constructor for class io.aleph0.yap.core.task.DefaultTaskController
- DefaultTaskController.TaskPhase - Enum Class in io.aleph0.yap.core.task
-
The phase of the task.
- DefaultTaskController.TaskState - Enum Class in io.aleph0.yap.core.task
-
The internal state of a task.
- DefaultTopic<T> - Class in io.aleph0.yap.core.transport.topic
- DefaultTopic(List<Channel<T>>) - Constructor for class io.aleph0.yap.core.transport.topic.DefaultTopic
- DefaultTopic.Builder<T> - Class in io.aleph0.yap.core.transport.topic
- depth() - Method in record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Returns the value of the
depthrecord component. - DirectedGraphs - Class in io.aleph0.yap.core.util
E
- equals(Object) - Method in record class io.aleph0.yap.core.pipeline.action.CancelPipelineAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.pipeline.action.CancelTaskPipelineAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.pipeline.action.FailPipelineAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.pipeline.action.StartTaskPipelineAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.pipeline.action.SucceedPipelineAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.Pipeline.Metrics
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.pipeline.PipelineManager.Metrics
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.task.action.CancelTaskAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.task.action.FailTaskAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.task.action.StartWorkerTaskAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.task.action.StopWorkerTaskAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.task.action.SucceedTaskAction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.transport.Queue.Metrics
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.transport.Topic.Metrics
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.aleph0.yap.core.util.NoMetrics
-
Indicates whether some other object is "equal to" this one.
- exceptionalCompletions() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
exceptionalCompletionsrecord component.
F
- fail(ExecutionException) - Static method in interface io.aleph0.yap.core.pipeline.action.PipelineAction
- FAILED - Enum constant in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
The pipeline is done processing and has shut down.
- FAILED - Enum constant in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
- FAILED - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
The task is done processing and has shut down.
- FAILED - Enum constant in enum class io.aleph0.yap.core.task.TaskManager.TaskState
- FAILING - Enum constant in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
One or more tasks have
failedand the pipeline is in the process of shutting down. - FAILING - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
One or more workers have
completed exceptionallyand the task is in the process of shutting down. - FailPipelineAction - Record Class in io.aleph0.yap.core.pipeline.action
- FailPipelineAction(ExecutionException) - Constructor for record class io.aleph0.yap.core.pipeline.action.FailPipelineAction
-
Creates an instance of a
FailPipelineActionrecord class. - FailTaskAction - Record Class in io.aleph0.yap.core.task.action
- FailTaskAction(ExecutionException) - Constructor for record class io.aleph0.yap.core.task.action.FailTaskAction
-
Creates an instance of a
FailTaskActionrecord class. - FilterProcessorWorker<T> - Class in io.aleph0.yap.core.worker
-
A
ProcessorWorkerthat filters items from a source to a sink using a providedpredicate. - FilterProcessorWorker(Predicate<T>) - Constructor for class io.aleph0.yap.core.worker.FilterProcessorWorker
- findCycle(Map<String, Set<String>>) - Static method in class io.aleph0.yap.core.util.DirectedGraphs
-
Finds some cycle in the given directed graph, if any exist.
- FINISHED - Enum constant in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelinePhase
- FINISHED - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskPhase
-
The task is done.
- FINISHED - Enum constant in enum class io.aleph0.yap.core.task.TaskManager.TaskPhase
- FINISHING - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskPhase
-
The task is shutting down.
- FlatMapProcessorWorker<X,
Y> - Class in io.aleph0.yap.core.worker -
A
ProcessorWorkerthat performs a simple one-to-many mapping of items from a source to a sink using a provided function. - FlatMapProcessorWorker(Function<X, Collection<Y>>) - Constructor for class io.aleph0.yap.core.worker.FlatMapProcessorWorker
- flushMetrics() - Method in interface io.aleph0.yap.core.Measureable
-
Destructive read of the metrics.
- flushMetrics() - Method in class io.aleph0.yap.core.pipeline.DefaultPipeline
- flushMetrics() - Method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- flushMetrics() - Method in class io.aleph0.yap.core.pipeline.PipelineManager
- flushMetrics() - Method in class io.aleph0.yap.core.task.TaskManager
- flushMetrics() - Method in interface io.aleph0.yap.core.task.TaskManager.WorkerBodyFactory
- flushMetrics() - Method in class io.aleph0.yap.core.transport.queue.DefaultQueue
- flushMetrics() - Method in class io.aleph0.yap.core.transport.topic.DefaultTopic
- flushMetrics() - Method in class io.aleph0.yap.core.worker.DefaultConsumerWorkerFactory
- flushMetrics() - Method in class io.aleph0.yap.core.worker.DefaultProcessorWorkerFactory
- flushMetrics() - Method in class io.aleph0.yap.core.worker.DefaultProducerWorkerFactory
- flushMetrics() - Method in class io.aleph0.yap.core.worker.SingletonConsumerWorkerFactory
- flushMetrics() - Method in class io.aleph0.yap.core.worker.SingletonProcessorWorkerFactory
- flushMetrics() - Method in class io.aleph0.yap.core.worker.SingletonProducerWorkerFactory
G
- getHeartbeatInterval() - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- getHeartbeatInterval() - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
The maximum amount of time to wait for a lifecycle event, after which
PipelineController.onHeartbeat()will be called. - getHeartbeatInterval() - Method in class io.aleph0.yap.core.task.DefaultTaskController
- getHeartbeatInterval() - Method in interface io.aleph0.yap.core.task.TaskController
-
The maximum amount of time to wait for a lifecycle event, after which
TaskController.onHeartbeat()will be called. - getId() - Method in class io.aleph0.yap.core.build.ConsumerTaskBuilder
- getId() - Method in class io.aleph0.yap.core.build.ProcessorTaskBuilder
- getId() - Method in class io.aleph0.yap.core.build.ProducerTaskBuilder
- getId() - Method in interface io.aleph0.yap.core.build.TaskBuilder
- getId() - Method in class io.aleph0.yap.core.pipeline.DefaultPipeline
- getId() - Method in interface io.aleph0.yap.core.Pipeline
- getId() - Method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- getId() - Method in class io.aleph0.yap.core.pipeline.PipelineManager
- getId() - Method in class io.aleph0.yap.core.task.TaskManager
- getPhase() - Method in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
- getPhase() - Method in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
- getPhase() - Method in enum class io.aleph0.yap.core.task.TaskManager.TaskState
- getSubscribers() - Method in class io.aleph0.yap.core.task.TaskManager
H
- hashCode() - Method in record class io.aleph0.yap.core.pipeline.action.CancelPipelineAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.pipeline.action.CancelTaskPipelineAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.pipeline.action.FailPipelineAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.pipeline.action.StartTaskPipelineAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.pipeline.action.SucceedPipelineAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.Pipeline.Metrics
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.pipeline.PipelineManager.Metrics
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.task.action.CancelTaskAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.task.action.FailTaskAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.task.action.StartWorkerTaskAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.task.action.StopWorkerTaskAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.task.action.SucceedTaskAction
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.transport.Queue.Metrics
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.transport.Topic.Metrics
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.aleph0.yap.core.util.NoMetrics
-
Returns a hash code value for this object.
I
- id() - Method in record class io.aleph0.yap.core.pipeline.action.CancelTaskPipelineAction
-
Returns the value of the
idrecord component. - id() - Method in record class io.aleph0.yap.core.pipeline.action.StartTaskPipelineAction
-
Returns the value of the
idrecord component. - id() - Method in record class io.aleph0.yap.core.Pipeline.Metrics
-
Returns the value of the
idrecord component. - id() - Method in record class io.aleph0.yap.core.pipeline.PipelineManager.Metrics
-
Returns the value of the
idrecord component. - id() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
idrecord component. - INSTANCE - Static variable in record class io.aleph0.yap.core.util.NoMetrics
- io.aleph0.yap.core - package io.aleph0.yap.core
- io.aleph0.yap.core.build - package io.aleph0.yap.core.build
- io.aleph0.yap.core.pipeline - package io.aleph0.yap.core.pipeline
- io.aleph0.yap.core.pipeline.action - package io.aleph0.yap.core.pipeline.action
- io.aleph0.yap.core.task - package io.aleph0.yap.core.task
- io.aleph0.yap.core.task.action - package io.aleph0.yap.core.task.action
- io.aleph0.yap.core.transport - package io.aleph0.yap.core.transport
- io.aleph0.yap.core.transport.channel - package io.aleph0.yap.core.transport.channel
- io.aleph0.yap.core.transport.queue - package io.aleph0.yap.core.transport.queue
- io.aleph0.yap.core.transport.topic - package io.aleph0.yap.core.transport.topic
- io.aleph0.yap.core.util - package io.aleph0.yap.core.util
- io.aleph0.yap.core.worker - package io.aleph0.yap.core.worker
- isDrained() - Method in class io.aleph0.yap.core.transport.queue.DefaultQueue
- isDrained() - Method in interface io.aleph0.yap.core.transport.Queue
- isWeaklyConnected(Map<String, Set<String>>) - Static method in class io.aleph0.yap.core.util.DirectedGraphs
-
Checks if the given directed graph is weakly connected.
M
- MapProcessorWorker<X,
Y> - Class in io.aleph0.yap.core.worker -
A
ProcessorWorkerthat performs a simple one-to-one mapping of items from a source to a sink using a provided function. - MapProcessorWorker(Function<X, Y>) - Constructor for class io.aleph0.yap.core.worker.MapProcessorWorker
- Measureable<M> - Interface in io.aleph0.yap.core
-
An object that can produce metrics.
- MeasuredConsumerWorker<InputT,
MetricsT> - Interface in io.aleph0.yap.core.worker - MeasuredProcessorWorker<InputT,
OutputT, - Interface in io.aleph0.yap.core.workerMetricsT> - MeasuredProducerWorker<OutputT,
MetricsT> - Interface in io.aleph0.yap.core.worker - Metrics(int, long, long, long, long) - Constructor for record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Creates an instance of a
Metricsrecord class. - Metrics(int, PipelineManager.PipelinePhase, PipelineManager.PipelineState, Map<String, TaskManager.Metrics<?>>) - Constructor for record class io.aleph0.yap.core.Pipeline.Metrics
-
Creates an instance of a
Metricsrecord class. - Metrics(int, PipelineManager.PipelinePhase, PipelineManager.PipelineState, Map<String, TaskManager.Metrics<?>>) - Constructor for record class io.aleph0.yap.core.pipeline.PipelineManager.Metrics
-
Creates an instance of a
Metricsrecord class. - Metrics(long, long) - Constructor for record class io.aleph0.yap.core.transport.Topic.Metrics
-
Creates an instance of a
Metricsrecord class. - Metrics(long, long, long, long, long) - Constructor for record class io.aleph0.yap.core.transport.Queue.Metrics
-
Creates an instance of a
Metricsrecord class. - Metrics(String, TaskManager.TaskPhase, TaskManager.TaskState, WorkerMetricsT, long, long, long, long, long, long, long, long, long, long, long) - Constructor for record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Creates an instance of a
Metricsrecord class. - MonitoredPipeline - Class in io.aleph0.yap.core.pipeline
- MonitoredPipeline(Pipeline, MonitoredPipeline.MetricsReporter) - Constructor for class io.aleph0.yap.core.pipeline.MonitoredPipeline
- MonitoredPipeline(Pipeline, MonitoredPipeline.MetricsReporter, Duration) - Constructor for class io.aleph0.yap.core.pipeline.MonitoredPipeline
- MonitoredPipeline(ScheduledExecutorService, Pipeline, MonitoredPipeline.MetricsReporter, Duration) - Constructor for class io.aleph0.yap.core.pipeline.MonitoredPipeline
- MonitoredPipeline.MetricsReporter - Interface in io.aleph0.yap.core.pipeline
N
- newCancelTask() - Static method in interface io.aleph0.yap.core.task.action.TaskAction
- newConsumerWorker() - Method in interface io.aleph0.yap.core.worker.ConsumerWorkerFactory
- newConsumerWorker() - Method in class io.aleph0.yap.core.worker.DefaultConsumerWorkerFactory
- newConsumerWorker() - Method in class io.aleph0.yap.core.worker.SingletonConsumerWorkerFactory
- newFailTask(ExecutionException) - Static method in interface io.aleph0.yap.core.task.action.TaskAction
- newProcessorWorker() - Method in class io.aleph0.yap.core.worker.DefaultProcessorWorkerFactory
- newProcessorWorker() - Method in interface io.aleph0.yap.core.worker.ProcessorWorkerFactory
-
Creates a new
worker - newProcessorWorker() - Method in class io.aleph0.yap.core.worker.SingletonProcessorWorkerFactory
- newProducerWorker() - Method in class io.aleph0.yap.core.worker.DefaultProducerWorkerFactory
- newProducerWorker() - Method in interface io.aleph0.yap.core.worker.ProducerWorkerFactory
-
Creates a new
worker - newProducerWorker() - Method in class io.aleph0.yap.core.worker.SingletonProducerWorkerFactory
- newStartWorkerTaskAction() - Static method in interface io.aleph0.yap.core.task.action.TaskAction
- newStopWorkerTaskAction() - Static method in interface io.aleph0.yap.core.task.action.TaskAction
- newSucceedTask() - Static method in interface io.aleph0.yap.core.task.action.TaskAction
- newWorkerBody() - Method in interface io.aleph0.yap.core.task.TaskManager.WorkerBodyFactory
- newWrapper() - Static method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- newWrapper(MonitoredPipeline.MetricsReporter) - Static method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- newWrapper(MonitoredPipeline.MetricsReporter, Duration) - Static method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- NoMetrics - Record Class in io.aleph0.yap.core.util
- NoMetrics() - Constructor for record class io.aleph0.yap.core.util.NoMetrics
-
Creates an instance of a
NoMetricsrecord class. - normalCompletions() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
normalCompletionsrecord component.
O
- onCancelRequested() - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onCancelRequested() - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when the pipeline has been requested to be cancelled.
- onCancelRequested() - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onCancelRequested() - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when the user has requested to cancel this task.
- onHeartbeat() - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onHeartbeat() - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when no lifecycle events have occurred within
the heartbeat interval. - onHeartbeat() - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onHeartbeat() - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when no lifecycle events have occurred within
the heartbeat interval. - onPipelineCancelled() - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onPipelineCancelled() - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when the pipeline has been cancelled.
- onPipelineCancelled(int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineCancelled(int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineCancelRequested(int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineCancelRequested(int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineCompleted() - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onPipelineCompleted() - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when the pipeline has been completed.
- onPipelineCompleted(int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineCompleted(int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineFailed(int, Throwable) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineFailed(int, Throwable) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineFailed(ExecutionException) - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onPipelineFailed(ExecutionException) - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when the pipeline has failed.
- onPipelineStarted() - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onPipelineStarted() - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when the pipeline has been started.
- onPipelineStarted(int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineStarted(int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskCancelled(int, String) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskCancelled(int, String) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskCancelRequested(int, String, int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskCancelRequested(int, String, int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskCompleted(int, String) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskCompleted(int, String) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskFailed(int, String, Throwable) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskFailed(int, String, Throwable) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskStarted(int, String) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskStarted(int, String) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskWorkerCompletedExceptionally(int, String, int, Throwable) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskWorkerCompletedExceptionally(int, String, int, Throwable) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskWorkerCompletedNormally(int, String, int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskWorkerCompletedNormally(int, String, int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskWorkerStarted(int, String, int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskWorkerStarted(int, String, int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskWorkerStopped(int, String, int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskWorkerStopped(int, String, int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onPipelineTaskWorkerStopRequested(int, String, int) - Method in interface io.aleph0.yap.core.Pipeline.LifecycleListener
- onPipelineTaskWorkerStopRequested(int, String, int) - Method in interface io.aleph0.yap.core.pipeline.PipelineManager.LifecycleListener
- onTaskCancelled() - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onTaskCancelled() - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when the task has been cancelled.
- onTaskCancelled(String) - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onTaskCancelled(String) - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when a task has been cancelled.
- onTaskCancelled(String) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskCancelRequested(String, int) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskCompleted(String) - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onTaskCompleted(String) - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when a task has been completed.
- onTaskCompleted(String) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskFailed(String, Throwable) - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onTaskFailed(String, Throwable) - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when a task has failed.
- onTaskFailed(String, ExecutionException) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskFailed(ExecutionException) - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onTaskFailed(ExecutionException) - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when the task has failed.
- onTaskStart() - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onTaskStart() - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when a task has been started.
- onTaskStarted(String) - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController
- onTaskStarted(String) - Method in interface io.aleph0.yap.core.pipeline.PipelineController
-
Called when a task has been started.
- onTaskStarted(String) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskSucceeded() - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onTaskSucceeded() - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when the task has been successfully completed.
- onTaskWorkerCompletedExceptionally(String, int, Throwable) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskWorkerCompletedNormally(String, int) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskWorkerStarted(String, int) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskWorkerStopped(String, int) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onTaskWorkerStopRequested(String, int) - Method in interface io.aleph0.yap.core.task.TaskManager.LifecycleListener
- onWorkerCompletedExceptionally(int, Throwable) - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onWorkerCompletedExceptionally(int, Throwable) - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when a worker completed exceptionally by propagating an exception.
- onWorkerCompletedNormally(int) - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onWorkerCompletedNormally(int) - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when a worker completed normally, for example because all input messages were processed.
- onWorkerStarted(int) - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onWorkerStarted(int) - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when a worker was started successfully in response to a start request.
- onWorkerStopped(int) - Method in class io.aleph0.yap.core.task.DefaultTaskController
- onWorkerStopped(int) - Method in interface io.aleph0.yap.core.task.TaskController
-
Called when a worker was stopped in response to a stop request.
P
- pending() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
pendingrecord component. - pending() - Method in record class io.aleph0.yap.core.transport.Queue.Metrics
-
Returns the value of the
pendingrecord component. - phase() - Method in record class io.aleph0.yap.core.Pipeline.Metrics
-
Returns the value of the
phaserecord component. - phase() - Method in record class io.aleph0.yap.core.pipeline.PipelineManager.Metrics
-
Returns the value of the
phaserecord component. - phase() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
phaserecord component. - Pipeline - Interface in io.aleph0.yap.core
- Pipeline.LifecycleListener - Interface in io.aleph0.yap.core
- Pipeline.Metrics - Record Class in io.aleph0.yap.core
- PipelineAction - Interface in io.aleph0.yap.core.pipeline.action
- PipelineBuilder - Class in io.aleph0.yap.core.build
- PipelineBuilder() - Constructor for class io.aleph0.yap.core.build.PipelineBuilder
- PipelineController - Interface in io.aleph0.yap.core.pipeline
-
The PipelineController is responsible for controlling the lifecycle of a
Pipeline. - PipelineControllerBuilder - Interface in io.aleph0.yap.core.build
- PipelineManager - Class in io.aleph0.yap.core.pipeline
-
PipelineManager is a class that manages the lifecycle of a
Pipeline, including ask lifecycle and lifecycle listeners. - PipelineManager(int, ExecutorService, PipelineController, List<TaskManager<?>>) - Constructor for class io.aleph0.yap.core.pipeline.PipelineManager
- PipelineManager.LifecycleListener - Interface in io.aleph0.yap.core.pipeline
- PipelineManager.Metrics - Record Class in io.aleph0.yap.core.pipeline
- PipelineManager.PipelinePhase - Enum Class in io.aleph0.yap.core.pipeline
- PipelineManager.PipelineState - Enum Class in io.aleph0.yap.core.pipeline
- PipelineWrapper - Interface in io.aleph0.yap.core.pipeline
- process(Source<InputT>, Sink<OutputT>) - Method in interface io.aleph0.yap.core.ProcessorWorker
- process(Source<T>, Sink<T>) - Method in class io.aleph0.yap.core.worker.FilterProcessorWorker
- process(Source<X>, Sink<Y>) - Method in class io.aleph0.yap.core.worker.FlatMapProcessorWorker
- process(Source<X>, Sink<Y>) - Method in class io.aleph0.yap.core.worker.MapProcessorWorker
- ProcessorTaskBuilder<InputT,
OutputT, - Class in io.aleph0.yap.core.buildMetricsT> - ProcessorWorker<InputT,
OutputT> - Interface in io.aleph0.yap.core - ProcessorWorkerFactory<InputT,
OutputT, - Interface in io.aleph0.yap.core.workerMetricsT> - produce(Sink<OutputT>) - Method in interface io.aleph0.yap.core.ProducerWorker
- produced() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
producedrecord component. - produced() - Method in record class io.aleph0.yap.core.transport.Queue.Metrics
-
Returns the value of the
producedrecord component. - ProducerTaskBuilder<OutputT,
MetricsT> - Class in io.aleph0.yap.core.build - ProducerWorker<OutputT> - Interface in io.aleph0.yap.core
-
A worker that produces outputs via a
sink. - ProducerWorkerFactory<OutputT,
MetricsT> - Interface in io.aleph0.yap.core.worker - publish(T) - Method in interface io.aleph0.yap.core.transport.Channel.Binding
-
Delivers the message, blocking if necessary.
- publish(T) - Method in class io.aleph0.yap.core.transport.channel.DefaultChannel
- publish(T) - Method in interface io.aleph0.yap.core.transport.Channel
- publish(T) - Method in class io.aleph0.yap.core.transport.topic.DefaultTopic
- publish(T) - Method in interface io.aleph0.yap.core.transport.Topic
- published() - Method in record class io.aleph0.yap.core.transport.Topic.Metrics
-
Returns the value of the
publishedrecord component. - put(T) - Method in interface io.aleph0.yap.core.Sink
Q
- Queue<T> - Interface in io.aleph0.yap.core.transport
- Queue.Metrics - Record Class in io.aleph0.yap.core.transport
- QueueBuilder<T> - Interface in io.aleph0.yap.core.build
R
- READY - Enum constant in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
The initial state of the pipeline.
- READY - Enum constant in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelinePhase
- READY - Enum constant in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
- READY - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
The initial state of the task.
- READY - Enum constant in enum class io.aleph0.yap.core.task.TaskManager.TaskPhase
- READY - Enum constant in enum class io.aleph0.yap.core.task.TaskManager.TaskState
- receive() - Method in class io.aleph0.yap.core.transport.queue.DefaultQueue
- receive() - Method in interface io.aleph0.yap.core.transport.Queue
-
Receives a message from the queue, waiting if necessary.
- receive(Duration) - Method in class io.aleph0.yap.core.transport.queue.DefaultQueue
- receive(Duration) - Method in interface io.aleph0.yap.core.transport.Queue
-
Receives a message from the queue, waiting if necessary.
- received() - Method in record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Returns the value of the
receivedrecord component. - removeLifecycleListener(Pipeline.LifecycleListener) - Method in class io.aleph0.yap.core.pipeline.DefaultPipeline
- removeLifecycleListener(Pipeline.LifecycleListener) - Method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- removeLifecycleListener(Pipeline.LifecycleListener) - Method in interface io.aleph0.yap.core.Pipeline
- removeLifecycleListener(PipelineManager.LifecycleListener) - Method in class io.aleph0.yap.core.pipeline.PipelineManager
- removeLifecycleListener(TaskManager.LifecycleListener) - Method in class io.aleph0.yap.core.task.TaskManager
- reportMetrics(Pipeline.Metrics) - Method in interface io.aleph0.yap.core.pipeline.MonitoredPipeline.MetricsReporter
- run() - Method in class io.aleph0.yap.core.pipeline.PipelineManager
- run() - Method in class io.aleph0.yap.core.task.TaskManager
- run() - Method in interface io.aleph0.yap.core.task.TaskManager.WorkerBody
- RUNNING - Enum constant in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
The pipeline is running.
- RUNNING - Enum constant in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelinePhase
- RUNNING - Enum constant in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
- RUNNING - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskPhase
-
The task is running.
- RUNNING - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
The task is running.
- RUNNING - Enum constant in enum class io.aleph0.yap.core.task.TaskManager.TaskPhase
- RUNNING - Enum constant in enum class io.aleph0.yap.core.task.TaskManager.TaskState
S
- sent() - Method in record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Returns the value of the
sentrecord component. - setCapacity(int) - Method in class io.aleph0.yap.core.transport.queue.DefaultQueue.Builder
- setController(TaskController.ConsumerTaskControllerBuilder<InputT>) - Method in class io.aleph0.yap.core.build.ConsumerTaskBuilder
- setController(TaskController.ProcessorTaskControllerBuilder<InputT, OutputT>) - Method in class io.aleph0.yap.core.build.ProcessorTaskBuilder
- setController(TaskController.ProducerTaskControllerBuilder<OutputT>) - Method in class io.aleph0.yap.core.build.ProducerTaskBuilder
- setDesiredConcurrency(int) - Method in class io.aleph0.yap.core.task.DefaultConsumerTaskController.Builder
- setDesiredConcurrency(int) - Method in class io.aleph0.yap.core.task.DefaultProcessorTaskController.Builder
- setDesiredConcurrency(int) - Method in class io.aleph0.yap.core.task.DefaultProducerTaskController.Builder
- setExecutor(ExecutorService) - Method in class io.aleph0.yap.core.build.PipelineBuilder
- setHeartbeatInterval(Duration) - Method in class io.aleph0.yap.core.pipeline.DefaultPipelineController.Builder
- setHeartbeatInterval(Duration) - Method in class io.aleph0.yap.core.task.DefaultConsumerTaskController.Builder
- setHeartbeatInterval(Duration) - Method in class io.aleph0.yap.core.task.DefaultProcessorTaskController.Builder
- setHeartbeatInterval(Duration) - Method in class io.aleph0.yap.core.task.DefaultProducerTaskController.Builder
- setPipelineController(PipelineControllerBuilder) - Method in class io.aleph0.yap.core.build.PipelineBuilder
- setQueue(QueueBuilder<InputT>) - Method in class io.aleph0.yap.core.build.ConsumerTaskBuilder
- setQueue(QueueBuilder<InputT>) - Method in class io.aleph0.yap.core.build.ProcessorTaskBuilder
- setTopic(TopicBuilder<OutputT>) - Method in class io.aleph0.yap.core.build.ProcessorTaskBuilder
- setTopic(TopicBuilder<OutputT>) - Method in class io.aleph0.yap.core.build.ProducerTaskBuilder
- SingletonConsumerWorkerFactory<InputT,
MetricsT> - Class in io.aleph0.yap.core.worker -
A
ConsumerWorkerFactorythat manages a singletonMeasuredConsumerWorkerand tracks its metrics. - SingletonConsumerWorkerFactory(MeasuredConsumerWorker<InputT, MetricsT>) - Constructor for class io.aleph0.yap.core.worker.SingletonConsumerWorkerFactory
- SingletonProcessorWorkerFactory<InputT,
OutputT, - Class in io.aleph0.yap.core.workerMetricsT> -
A
ProcessorWorkerFactorythat manages a singletonMeasuredProcessorWorkerand tracks its metrics. - SingletonProcessorWorkerFactory(MeasuredProcessorWorker<InputT, OutputT, MetricsT>) - Constructor for class io.aleph0.yap.core.worker.SingletonProcessorWorkerFactory
- SingletonProducerWorkerFactory<OutputT,
MetricsT> - Class in io.aleph0.yap.core.worker -
A
ProducerWorkerFactorythat manages a singletonMeasuredProducerWorkerand tracks its metrics. - SingletonProducerWorkerFactory(MeasuredProducerWorker<OutputT, MetricsT>) - Constructor for class io.aleph0.yap.core.worker.SingletonProducerWorkerFactory
- Sink<T> - Interface in io.aleph0.yap.core
- Source<T> - Interface in io.aleph0.yap.core
- stalls() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
stallsrecord component. - stalls() - Method in record class io.aleph0.yap.core.transport.Queue.Metrics
-
Returns the value of the
stallsrecord component. - stalls() - Method in record class io.aleph0.yap.core.transport.Topic.Metrics
-
Returns the value of the
stallsrecord component. - start() - Method in class io.aleph0.yap.core.pipeline.DefaultPipeline
- start() - Method in class io.aleph0.yap.core.pipeline.MonitoredPipeline
- start() - Method in interface io.aleph0.yap.core.Pipeline
- STARTING - Enum constant in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskPhase
-
The task is starting up.
- startTask(String) - Static method in interface io.aleph0.yap.core.pipeline.action.PipelineAction
- StartTaskPipelineAction - Record Class in io.aleph0.yap.core.pipeline.action
- StartTaskPipelineAction(String) - Constructor for record class io.aleph0.yap.core.pipeline.action.StartTaskPipelineAction
-
Creates an instance of a
StartTaskPipelineActionrecord class. - startWorker() - Method in class io.aleph0.yap.core.task.TaskManager
- StartWorkerTaskAction - Record Class in io.aleph0.yap.core.task.action
- StartWorkerTaskAction() - Constructor for record class io.aleph0.yap.core.task.action.StartWorkerTaskAction
-
Creates an instance of a
StartWorkerTaskActionrecord class. - state() - Method in record class io.aleph0.yap.core.Pipeline.Metrics
-
Returns the value of the
staterecord component. - state() - Method in record class io.aleph0.yap.core.pipeline.PipelineManager.Metrics
-
Returns the value of the
staterecord component. - state() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
staterecord component. - stderr() - Static method in interface io.aleph0.yap.core.pipeline.MonitoredPipeline.MetricsReporter
- stdout() - Static method in interface io.aleph0.yap.core.pipeline.MonitoredPipeline.MetricsReporter
- stopAllWorkers() - Method in class io.aleph0.yap.core.task.TaskManager
- stopAnyWorker() - Method in class io.aleph0.yap.core.task.TaskManager
- stopCompletions() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
stopCompletionsrecord component. - StopWorkerTaskAction - Record Class in io.aleph0.yap.core.task.action
- StopWorkerTaskAction() - Constructor for record class io.aleph0.yap.core.task.action.StopWorkerTaskAction
-
Creates an instance of a
StopWorkerTaskActionrecord class. - succeed() - Static method in interface io.aleph0.yap.core.pipeline.action.PipelineAction
- SUCCEEDED - Enum constant in enum class io.aleph0.yap.core.task.TaskManager.TaskState
- SucceedPipelineAction - Record Class in io.aleph0.yap.core.pipeline.action
- SucceedPipelineAction() - Constructor for record class io.aleph0.yap.core.pipeline.action.SucceedPipelineAction
-
Creates an instance of a
SucceedPipelineActionrecord class. - SucceedTaskAction - Record Class in io.aleph0.yap.core.task.action
- SucceedTaskAction() - Constructor for record class io.aleph0.yap.core.task.action.SucceedTaskAction
-
Creates an instance of a
SucceedTaskActionrecord class.
T
- take() - Method in interface io.aleph0.yap.core.Source
- take(Duration) - Method in interface io.aleph0.yap.core.Source
- TaskAction - Interface in io.aleph0.yap.core.task.action
- TaskBuilder - Interface in io.aleph0.yap.core.build
- TaskController - Interface in io.aleph0.yap.core.task
-
The TaskController is responsible for controlling the lifecycle of a task.
- TaskController.ConsumerTaskControllerBuilder<InputT> - Interface in io.aleph0.yap.core.task
- TaskController.ProcessorTaskControllerBuilder<InputT,
OutputT> - Interface in io.aleph0.yap.core.task - TaskController.ProducerTaskControllerBuilder<OutputT> - Interface in io.aleph0.yap.core.task
- TaskManager<WorkerMetricsT> - Class in io.aleph0.yap.core.task
-
TaskManager manages the lifecycle of a logical pipeline task, including starting and stopping workers, handling task actions, and notifying lifecycle listeners.
- TaskManager(String, Set<String>, ExecutorService, TaskController, TaskManager.WorkerBodyFactory<WorkerMetricsT>, Queue<?>, Topic<?>) - Constructor for class io.aleph0.yap.core.task.TaskManager
- TaskManager.LifecycleListener - Interface in io.aleph0.yap.core.task
- TaskManager.Metrics<WorkerMetricsT> - Record Class in io.aleph0.yap.core.task
- TaskManager.TaskPhase - Enum Class in io.aleph0.yap.core.task
- TaskManager.TaskState - Enum Class in io.aleph0.yap.core.task
- TaskManager.WorkerBody - Interface in io.aleph0.yap.core.task
- TaskManager.WorkerBodyFactory<MetricsT> - Interface in io.aleph0.yap.core.task
- tasks() - Method in record class io.aleph0.yap.core.Pipeline.Metrics
-
Returns the value of the
tasksrecord component. - tasks() - Method in record class io.aleph0.yap.core.pipeline.PipelineManager.Metrics
-
Returns the value of the
tasksrecord component. - to(DefaultPipelineController.PipelineState) - Method in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
Validate the transition from this state to the target state.
- to(PipelineManager.PipelineState) - Method in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
-
Validates that the transition from this state to the target state is valid.
- to(DefaultTaskController.TaskState) - Method in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
Validate the transition from this state to the target state.
- to(TaskManager.TaskState) - Method in enum class io.aleph0.yap.core.task.TaskManager.TaskState
-
Validate that the transition to the target state is valid.
- Topic<T> - Interface in io.aleph0.yap.core.transport
- Topic.Metrics - Record Class in io.aleph0.yap.core.transport
- TopicBuilder<T> - Interface in io.aleph0.yap.core.build
- toString() - Method in record class io.aleph0.yap.core.pipeline.action.CancelPipelineAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.pipeline.action.CancelTaskPipelineAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.pipeline.action.FailPipelineAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.pipeline.action.StartTaskPipelineAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.pipeline.action.SucceedPipelineAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.Pipeline.Metrics
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.pipeline.PipelineManager.Metrics
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.task.action.CancelTaskAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.task.action.FailTaskAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.task.action.StartWorkerTaskAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.task.action.StopWorkerTaskAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.task.action.SucceedTaskAction
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.transport.Queue.Metrics
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.transport.Topic.Metrics
-
Returns a string representation of this record class.
- toString() - Method in record class io.aleph0.yap.core.util.NoMetrics
-
Returns a string representation of this record class.
- tryPublish(T) - Method in interface io.aleph0.yap.core.transport.Channel.Binding
-
Attempts to deliver the message immediately.
- tryPublish(T) - Method in class io.aleph0.yap.core.transport.channel.DefaultChannel
- tryPublish(T) - Method in interface io.aleph0.yap.core.transport.Channel
- tryReceive() - Method in class io.aleph0.yap.core.transport.queue.DefaultQueue
- tryReceive() - Method in interface io.aleph0.yap.core.transport.Queue
-
Attempts to receive a message from the queue.
- tryTake() - Method in interface io.aleph0.yap.core.Source
V
- valueOf(String) - Static method in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelinePhase
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskPhase
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.aleph0.yap.core.task.TaskManager.TaskPhase
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.aleph0.yap.core.task.TaskManager.TaskState
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class io.aleph0.yap.core.pipeline.DefaultPipelineController.PipelineState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelinePhase
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.aleph0.yap.core.pipeline.PipelineManager.PipelineState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskPhase
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.aleph0.yap.core.task.DefaultTaskController.TaskState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.aleph0.yap.core.task.TaskManager.TaskPhase
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class io.aleph0.yap.core.task.TaskManager.TaskState
-
Returns an array containing the constants of this enum class, in the order they are declared.
W
- waits() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
waitsrecord component. - waits() - Method in record class io.aleph0.yap.core.transport.queue.DefaultQueue.Metrics
-
Returns the value of the
waitsrecord component. - waits() - Method in record class io.aleph0.yap.core.transport.Queue.Metrics
-
Returns the value of the
waitsrecord component. - withNoMetrics(ConsumerWorker<InputT>) - Static method in interface io.aleph0.yap.core.worker.MeasuredConsumerWorker
- withNoMetrics(ProcessorWorker<InputT, OutputT>) - Static method in interface io.aleph0.yap.core.worker.MeasuredProcessorWorker
- withNoMetrics(ProducerWorker<OutputT>) - Static method in interface io.aleph0.yap.core.worker.MeasuredProducerWorker
- worker() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
workerrecord component. - workers() - Method in record class io.aleph0.yap.core.task.TaskManager.Metrics
-
Returns the value of the
workersrecord component. - wrapPipeline(Pipeline) - Method in interface io.aleph0.yap.core.pipeline.PipelineWrapper
All Classes and Interfaces|All Packages