Uses of Interface
org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
-
-
Uses of CheckpointableTask in org.apache.flink.runtime.iterative.task
Classes in org.apache.flink.runtime.iterative.task that implement CheckpointableTask Modifier and Type Class Description classAbstractIterativeTask<S extends org.apache.flink.api.common.functions.Function,OT>The abstract base class for all tasks able to participate in an iteration.classIterationHeadTask<X,Y,S extends org.apache.flink.api.common.functions.Function,OT>The head is responsible for coordinating an iteration and can run aDriverinside.classIterationIntermediateTask<S extends org.apache.flink.api.common.functions.Function,OT>An intermediate iteration task, which runs aDriverinside.classIterationSynchronizationSinkTaskThe task responsible for synchronizing all iteration heads, implemented as an output task.classIterationTailTask<S extends org.apache.flink.api.common.functions.Function,OT>An iteration tail, which runs a driver inside. -
Uses of CheckpointableTask in org.apache.flink.runtime.jobgraph.tasks
Classes in org.apache.flink.runtime.jobgraph.tasks that implement CheckpointableTask Modifier and Type Class Description classAbstractInvokableA base implementation ofTaskInvokable,CheckpointableTask, andCoordinatedTaskwith most methods throwingUnsupportedOperationExceptionor doing nothing. -
Uses of CheckpointableTask in org.apache.flink.runtime.operators
Classes in org.apache.flink.runtime.operators that implement CheckpointableTask Modifier and Type Class Description classBatchTask<S extends org.apache.flink.api.common.functions.Function,OT>The base class for all batch tasks.classDataSinkTask<IT>DataSinkTask which is executed by a task manager.classDataSourceTask<OT>DataSourceTask which is executed by a task manager. -
Uses of CheckpointableTask in org.apache.flink.streaming.runtime.io.checkpointing
Methods in org.apache.flink.streaming.runtime.io.checkpointing with parameters of type CheckpointableTask Modifier and Type Method Description static SingleCheckpointBarrierHandlerSingleCheckpointBarrierHandler. aligned(String taskName, CheckpointableTask toNotifyOnCheckpoint, org.apache.flink.util.clock.Clock clock, int numOpenChannels, BarrierAlignmentUtil.DelayableTimer registerTimer, boolean enableCheckpointAfterTasksFinished, CheckpointableInput... inputs)static SingleCheckpointBarrierHandlerSingleCheckpointBarrierHandler. alternating(String taskName, CheckpointableTask toNotifyOnCheckpoint, SubtaskCheckpointCoordinator checkpointCoordinator, org.apache.flink.util.clock.Clock clock, int numOpenChannels, BarrierAlignmentUtil.DelayableTimer registerTimer, boolean enableCheckpointAfterTasksFinished, CheckpointableInput... inputs)static CheckpointBarrierHandlerInputProcessorUtil. createCheckpointBarrierHandler(CheckpointableTask toNotifyOnCheckpoint, StreamConfig config, SubtaskCheckpointCoordinator checkpointCoordinator, String taskName, List<IndexedInputGate>[] inputGates, List<StreamTaskSourceInput<?>> sourceInputs, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, TimerService timerService)static SingleCheckpointBarrierHandlerSingleCheckpointBarrierHandler. createUnalignedCheckpointBarrierHandler(SubtaskCheckpointCoordinator checkpointCoordinator, String taskName, CheckpointableTask toNotifyOnCheckpoint, org.apache.flink.util.clock.Clock clock, boolean enableCheckpointsAfterTasksFinish, CheckpointableInput... inputs)static SingleCheckpointBarrierHandlerSingleCheckpointBarrierHandler. unaligned(String taskName, CheckpointableTask toNotifyOnCheckpoint, SubtaskCheckpointCoordinator checkpointCoordinator, org.apache.flink.util.clock.Clock clock, int numOpenChannels, BarrierAlignmentUtil.DelayableTimer registerTimer, boolean enableCheckpointAfterTasksFinished, CheckpointableInput... inputs)Constructors in org.apache.flink.streaming.runtime.io.checkpointing with parameters of type CheckpointableTask Constructor Description CheckpointBarrierHandler(CheckpointableTask toNotifyOnCheckpoint, org.apache.flink.util.clock.Clock clock, boolean enableCheckpointAfterTasksFinished)CheckpointBarrierTracker(int totalNumberOfInputChannels, CheckpointableTask toNotifyOnCheckpoint, org.apache.flink.util.clock.Clock clock, boolean enableCheckpointAfterTasksFinished) -
Uses of CheckpointableTask in org.apache.flink.streaming.runtime.tasks
Classes in org.apache.flink.streaming.runtime.tasks that implement CheckpointableTask Modifier and Type Class Description classAbstractTwoInputStreamTask<IN1,IN2,OUT>Abstract class for executing aTwoInputStreamOperator.classMultipleInputStreamTask<OUT>AStreamTaskfor executing aMultipleInputStreamOperatorand supporting theMultipleInputStreamOperatorto select input for reading.classOneInputStreamTask<IN,OUT>AStreamTaskfor executing aOneInputStreamOperator.classSourceOperatorStreamTask<T>A subclass ofStreamTaskfor executing theSourceOperator.classSourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>>Deprecated.This class is based on theSourceFunctionAPI, which is due to be removed.classStreamIterationHead<OUT>A specialStreamTaskthat is used for executing feedback edges.classStreamIterationTail<IN>A specialStreamTaskthat is used for executing feedback edges.classStreamTask<OUT,OP extends StreamOperator<OUT>>Base class for all streaming tasks.classTwoInputStreamTask<IN1,IN2,OUT>AStreamTaskfor executing aTwoInputStreamOperatorand supporting theTwoInputStreamOperatorto select input for reading.
-