Uses of Package
org.apache.flink.streaming.runtime.tasks
-
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.cep.operator Class Description StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.connector.file.sink.compactor.operator Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.connector.file.table.stream Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.runtime.asyncprocessing.operators Class Description StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.state.api.output.operators Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
.StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.state.api.runtime Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.TimerService A common timer service interface with life cycle methods. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.connector.sink2 Class Description StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.functions.sink.filesystem Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.functions.source Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.operators Class Description OperatorChain TheOperatorChain
contains all operators that are executed as one chain within a singleStreamTask
.ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
.StreamTask Base class for all streaming tasks.StreamTask.CanEmitBatchOfRecordsChecker Check whether records can be emitted in batch.StreamTaskCancellationContext Context on theStreamTask
for figuring out whether it has been cancelled.WatermarkGaugeExposingOutput AnOutput
that measures the last emitted watermark with aWatermarkGauge
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.operators.async Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
.StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.operators.collect Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.operators.sorted.state Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.StreamTaskCancellationContext Context on theStreamTask
for figuring out whether it has been cancelled. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.operators.sortpartition Class Description StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.api.operators.source Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.runtime.io Class Description OperatorChain TheOperatorChain
contains all operators that are executed as one chain within a singleStreamTask
.OutputWithChainingCheck This is a wrapper for outputs to check whether the collected record has been emitted to a downstream subtask or to a chained operator.StreamTask.CanEmitBatchOfRecordsChecker Check whether records can be emitted in batch.WatermarkGaugeExposingOutput AnOutput
that measures the last emitted watermark with aWatermarkGauge
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.runtime.io.checkpointing Class Description SubtaskCheckpointCoordinator Coordinates checkpointing-related work for a subtask (i.e.TimerService A common timer service interface with life cycle methods. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.runtime.io.recovery Class Description StreamTask.CanEmitBatchOfRecordsChecker Check whether records can be emitted in batch. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.runtime.operators Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.runtime.operators.sink Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.runtime.operators.windowing Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
.StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.runtime.tasks Class Description AbstractTwoInputStreamTask Abstract class for executing aTwoInputStreamOperator
.ContainingTaskDetails Details about the operator containing task (such asStreamTask
).FinishedOnRestoreInput A fakeInput
for finished on restore tasks.OneInputStreamTask AStreamTask
for executing aOneInputStreamOperator
.OperatorChain TheOperatorChain
contains all operators that are executed as one chain within a singleStreamTask
.OperatorChain.ChainedSource Wrapper class to access the chained sources and their's outputs.OperatorEventDispatcherImpl An implementation of theOperatorEventDispatcher
.ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.ProcessingTimeServiceFactory A factory for creating processing time services with a givenMailboxExecutor
.StreamOperatorWrapper This class handles the finish, endInput and other related logic of aStreamOperator
.StreamTask Base class for all streaming tasks.StreamTask.CanEmitBatchOfRecordsChecker Check whether records can be emitted in batch.StreamTaskActionExecutor StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor Deprecated.this class should only be used inSourceStreamTask
which exposes the checkpoint lock as part of Public API.StreamTaskCancellationContext Context on theStreamTask
for figuring out whether it has been cancelled.TimerService A common timer service interface with life cycle methods.WatermarkGaugeExposingOutput AnOutput
that measures the last emitted watermark with aWatermarkGauge
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.streaming.runtime.tasks.mailbox Class Description StreamTaskActionExecutor TimerService A common timer service interface with life cycle methods. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.table.runtime.operators Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.table.runtime.operators.dynamicfiltering Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.table.runtime.operators.fusion Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
.StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.table.runtime.operators.join Class Description StreamTask Base class for all streaming tasks. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.table.runtime.operators.multipleinput Class Description ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
. -
Classes in org.apache.flink.streaming.runtime.tasks used by org.apache.flink.table.runtime.operators.wmassigners Class Description ProcessingTimeService Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.ProcessingTimeServiceAware Interface forStreamOperatorFactory
, which enables stream operators to accessProcessingTimeService
.