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 class
AbstractIterativeTask<S extends org.apache.flink.api.common.functions.Function,OT>
The abstract base class for all tasks able to participate in an iteration.class
IterationHeadTask<X,Y,S extends org.apache.flink.api.common.functions.Function,OT>
The head is responsible for coordinating an iteration and can run aDriver
inside.class
IterationIntermediateTask<S extends org.apache.flink.api.common.functions.Function,OT>
An intermediate iteration task, which runs aDriver
inside.class
IterationSynchronizationSinkTask
The task responsible for synchronizing all iteration heads, implemented as an output task.class
IterationTailTask<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 class
AbstractInvokable
A base implementation ofTaskInvokable
,CheckpointableTask
, andCoordinatedTask
with most methods throwingUnsupportedOperationException
or 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 class
BatchTask<S extends org.apache.flink.api.common.functions.Function,OT>
The base class for all batch tasks.class
DataSinkTask<IT>
DataSinkTask which is executed by a task manager.class
DataSourceTask<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 SingleCheckpointBarrierHandler
SingleCheckpointBarrierHandler. aligned(String taskName, CheckpointableTask toNotifyOnCheckpoint, org.apache.flink.util.clock.Clock clock, int numOpenChannels, BarrierAlignmentUtil.DelayableTimer registerTimer, boolean enableCheckpointAfterTasksFinished, CheckpointableInput... inputs)
static SingleCheckpointBarrierHandler
SingleCheckpointBarrierHandler. alternating(String taskName, CheckpointableTask toNotifyOnCheckpoint, SubtaskCheckpointCoordinator checkpointCoordinator, org.apache.flink.util.clock.Clock clock, int numOpenChannels, BarrierAlignmentUtil.DelayableTimer registerTimer, boolean enableCheckpointAfterTasksFinished, CheckpointableInput... inputs)
static CheckpointBarrierHandler
InputProcessorUtil. 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 SingleCheckpointBarrierHandler
SingleCheckpointBarrierHandler. createUnalignedCheckpointBarrierHandler(SubtaskCheckpointCoordinator checkpointCoordinator, String taskName, CheckpointableTask toNotifyOnCheckpoint, org.apache.flink.util.clock.Clock clock, boolean enableCheckpointsAfterTasksFinish, CheckpointableInput... inputs)
static SingleCheckpointBarrierHandler
SingleCheckpointBarrierHandler. 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 class
AbstractTwoInputStreamTask<IN1,IN2,OUT>
Abstract class for executing aTwoInputStreamOperator
.class
MultipleInputStreamTask<OUT>
AStreamTask
for executing aMultipleInputStreamOperator
and supporting theMultipleInputStreamOperator
to select input for reading.class
OneInputStreamTask<IN,OUT>
AStreamTask
for executing aOneInputStreamOperator
.class
SourceOperatorStreamTask<T>
A subclass ofStreamTask
for executing theSourceOperator
.class
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>>
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
StreamIterationHead<OUT>
A specialStreamTask
that is used for executing feedback edges.class
StreamIterationTail<IN>
A specialStreamTask
that is used for executing feedback edges.class
StreamTask<OUT,OP extends StreamOperator<OUT>>
Base class for all streaming tasks.class
TwoInputStreamTask<IN1,IN2,OUT>
AStreamTask
for executing aTwoInputStreamOperator
and supporting theTwoInputStreamOperator
to select input for reading.
-