Uses of Class
org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Packages that use OperatorChain Package Description org.apache.flink.streaming.api.operators org.apache.flink.streaming.runtime.io org.apache.flink.streaming.runtime.tasks This package contains classes that realize streaming tasks. -
-
Uses of OperatorChain in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type OperatorChain Modifier and Type Method Description void
StreamSource. run(Object lockingObject, Output<StreamRecord<OUT>> collector, OperatorChain<?,?> operatorChain)
Deprecated.void
StreamSource. run(Object lockingObject, OperatorChain<?,?> operatorChain)
Deprecated. -
Uses of OperatorChain in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type OperatorChain Modifier and Type Method Description static StreamMultipleInputProcessor
StreamMultipleInputProcessorFactory. create(TaskInvokable ownerTask, CheckpointedInputGate[] checkpointedInputGates, StreamConfig.InputConfig[] configuredInputs, IOManager ioManager, MemoryManager memoryManager, TaskIOMetricGroup ioMetricGroup, Counter mainOperatorRecordsIn, MultipleInputStreamOperator<?> mainOperator, WatermarkGauge[] inputWatermarkGauges, StreamConfig streamConfig, Configuration taskManagerConfig, Configuration jobConfig, ExecutionConfig executionConfig, ClassLoader userClassloader, OperatorChain<?,?> operatorChain, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
static <IN1,IN2>
StreamMultipleInputProcessorStreamTwoInputProcessorFactory. create(TaskInvokable ownerTask, CheckpointedInputGate[] checkpointedInputGates, IOManager ioManager, MemoryManager memoryManager, TaskIOMetricGroup taskIOMetricGroup, TwoInputStreamOperator<IN1,IN2,?> streamOperator, WatermarkGauge input1WatermarkGauge, WatermarkGauge input2WatermarkGauge, OperatorChain<?,?> operatorChain, StreamConfig streamConfig, Configuration taskManagerConfig, Configuration jobConfig, ExecutionConfig executionConfig, ClassLoader userClassloader, Counter numRecordsIn, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
-
Uses of OperatorChain in org.apache.flink.streaming.runtime.tasks
Subclasses of OperatorChain in org.apache.flink.streaming.runtime.tasks Modifier and Type Class Description class
FinishedOperatorChain<OUT,OP extends StreamOperator<OUT>>
TheOperatorChain
that is used for restoring tasks that areTaskStateManager.isTaskDeployedAsFinished()
.class
RegularOperatorChain<OUT,OP extends StreamOperator<OUT>>
A regular non finished on restoreOperatorChain
.Fields in org.apache.flink.streaming.runtime.tasks declared as OperatorChain Modifier and Type Field Description protected OperatorChain<OUT,OP>
StreamTask. operatorChain
The chain of operators executed by this task.Methods in org.apache.flink.streaming.runtime.tasks with parameters of type OperatorChain Modifier and Type Method Description void
SubtaskCheckpointCoordinator. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause, OperatorChain<?,?> operatorChain)
void
SubtaskCheckpointCoordinator. checkpointState(CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, CheckpointMetricsBuilder checkpointMetrics, OperatorChain<?,?> operatorChain, boolean isTaskFinished, Supplier<Boolean> isRunning)
Must be called afterSubtaskCheckpointCoordinator.initInputsCheckpoint(long, CheckpointOptions)
.void
SubtaskCheckpointCoordinator. notifyCheckpointAborted(long checkpointId, OperatorChain<?,?> operatorChain, Supplier<Boolean> isRunning)
Notified on the task side once a distributed checkpoint has been aborted.void
SubtaskCheckpointCoordinator. notifyCheckpointComplete(long checkpointId, OperatorChain<?,?> operatorChain, Supplier<Boolean> isRunning)
Notified on the task side once a distributed checkpoint has been completed.void
SubtaskCheckpointCoordinator. notifyCheckpointSubsumed(long checkpointId, OperatorChain<?,?> operatorChain, Supplier<Boolean> isRunning)
Notified on the task side once a distributed checkpoint has been subsumed.
-