Package | Description |
---|---|
org.apache.flink.runtime.iterative.task | |
org.apache.flink.runtime.jobgraph.tasks | |
org.apache.flink.runtime.operators | |
org.apache.flink.streaming.runtime.io.checkpointing | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractIterativeTask<S extends Function,OT>
The abstract base class for all tasks able to participate in an iteration.
|
class |
IterationHeadTask<X,Y,S extends Function,OT>
The head is responsible for coordinating an iteration and can run a
Driver inside. |
class |
IterationIntermediateTask<S extends Function,OT>
An intermediate iteration task, which runs a
Driver
inside. |
class |
IterationSynchronizationSinkTask
The task responsible for synchronizing all iteration heads, implemented as an output task.
|
class |
IterationTailTask<S extends Function,OT>
An iteration tail, which runs a driver inside.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractInvokable
A base implementation of
TaskInvokable , CheckpointableTask , and CoordinatedTask with most methods throwing UnsupportedOperationException or doing
nothing. |
Modifier and Type | Class and Description |
---|---|
class |
BatchTask<S extends 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.
|
Modifier and Type | Method and Description |
---|---|
static SingleCheckpointBarrierHandler |
SingleCheckpointBarrierHandler.aligned(String taskName,
CheckpointableTask toNotifyOnCheckpoint,
Clock clock,
int numOpenChannels,
BarrierAlignmentUtil.DelayableTimer registerTimer,
boolean enableCheckpointAfterTasksFinished,
CheckpointableInput... inputs) |
static SingleCheckpointBarrierHandler |
SingleCheckpointBarrierHandler.alternating(String taskName,
CheckpointableTask toNotifyOnCheckpoint,
SubtaskCheckpointCoordinator checkpointCoordinator,
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,
MailboxExecutor mailboxExecutor,
TimerService timerService) |
static SingleCheckpointBarrierHandler |
SingleCheckpointBarrierHandler.createUnalignedCheckpointBarrierHandler(SubtaskCheckpointCoordinator checkpointCoordinator,
String taskName,
CheckpointableTask toNotifyOnCheckpoint,
Clock clock,
boolean enableCheckpointsAfterTasksFinish,
CheckpointableInput... inputs) |
static SingleCheckpointBarrierHandler |
SingleCheckpointBarrierHandler.unaligned(String taskName,
CheckpointableTask toNotifyOnCheckpoint,
SubtaskCheckpointCoordinator checkpointCoordinator,
Clock clock,
int numOpenChannels,
BarrierAlignmentUtil.DelayableTimer registerTimer,
boolean enableCheckpointAfterTasksFinished,
CheckpointableInput... inputs) |
Constructor and Description |
---|
CheckpointBarrierHandler(CheckpointableTask toNotifyOnCheckpoint,
Clock clock,
boolean enableCheckpointAfterTasksFinished) |
CheckpointBarrierTracker(int totalNumberOfInputChannels,
CheckpointableTask toNotifyOnCheckpoint,
Clock clock,
boolean enableCheckpointAfterTasksFinished) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTwoInputStreamTask<IN1,IN2,OUT>
Abstract class for executing a
TwoInputStreamOperator . |
class |
MultipleInputStreamTask<OUT>
A
StreamTask for executing a MultipleInputStreamOperator and supporting the
MultipleInputStreamOperator to select input for reading. |
class |
OneInputStreamTask<IN,OUT>
A
StreamTask for executing a OneInputStreamOperator . |
class |
SourceOperatorStreamTask<T>
A subclass of
StreamTask for executing the SourceOperator . |
class |
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
StreamIterationHead<OUT>
A special
StreamTask that is used for executing feedback edges. |
class |
StreamIterationTail<IN>
A special
StreamTask 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>
A
StreamTask for executing a TwoInputStreamOperator and supporting the TwoInputStreamOperator to select input for reading. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.