Package | Description |
---|---|
org.apache.flink.runtime.iterative.task | |
org.apache.flink.runtime.jobgraph | |
org.apache.flink.runtime.jobgraph.tasks | |
org.apache.flink.runtime.operators | |
org.apache.flink.runtime.operators.sort | |
org.apache.flink.streaming.api.graph | |
org.apache.flink.streaming.api.operators.sort | |
org.apache.flink.streaming.runtime.io | |
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 | Method and Description |
---|---|
Class<? extends TaskInvokable> |
JobVertex.getInvokableClass(ClassLoader cl)
Returns the invokable class which represents the task of this vertex.
|
Modifier and Type | Method and Description |
---|---|
void |
JobVertex.setInvokableClass(Class<? extends TaskInvokable> invokable) |
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 <E> ExternalSorterBuilder<E> |
ExternalSorter.newBuilder(MemoryManager memoryManager,
TaskInvokable parentTask,
TypeSerializer<E> serializer,
TypeComparator<E> comparator,
ExecutionConfig executionConfig)
Creates a builder for the
ExternalSorter . |
Constructor and Description |
---|
LargeRecordHandler(TypeSerializer<T> serializer,
TypeComparator<T> comparator,
IOManager ioManager,
MemoryManager memManager,
List<MemorySegment> memory,
TaskInvokable memoryOwner,
int maxFilehandles,
ExecutionConfig executionConfig) |
Modifier and Type | Method and Description |
---|---|
Class<? extends TaskInvokable> |
StreamNode.getJobVertexClass() |
Modifier and Type | Method and Description |
---|---|
protected StreamNode |
StreamGraph.addNode(Integer vertexID,
String slotSharingGroup,
String coLocationGroup,
Class<? extends TaskInvokable> vertexClass,
StreamOperatorFactory<?> operatorFactory,
String operatorName) |
Constructor and Description |
---|
StreamNode(Integer id,
String slotSharingGroup,
String coLocationGroup,
StreamOperator<?> operator,
String operatorName,
Class<? extends TaskInvokable> jobVertexClass) |
StreamNode(Integer id,
String slotSharingGroup,
String coLocationGroup,
StreamOperatorFactory<?> operatorFactory,
String operatorName,
Class<? extends TaskInvokable> jobVertexClass) |
Modifier and Type | Method and Description |
---|---|
static <K> MultiInputSortingDataInput.SelectableSortingInputs |
MultiInputSortingDataInput.wrapInputs(TaskInvokable containingTask,
StreamTaskInput<Object>[] sortingInputs,
KeySelector<Object,K>[] keySelectors,
TypeSerializer<Object>[] inputSerializers,
TypeSerializer<K> keySerializer,
StreamTaskInput<Object>[] passThroughInputs,
MemoryManager memoryManager,
IOManager ioManager,
boolean objectReuse,
double managedMemoryFraction,
Configuration taskManagerConfiguration,
ExecutionConfig executionConfig) |
Constructor and Description |
---|
SortingDataInput(StreamTaskInput<T> wrappedInput,
TypeSerializer<T> typeSerializer,
TypeSerializer<K> keySerializer,
KeySelector<T,K> keySelector,
MemoryManager memoryManager,
IOManager ioManager,
boolean objectReuse,
double managedMemoryFraction,
Configuration taskManagerConfiguration,
TaskInvokable containingTask,
ExecutionConfig executionConfig) |
Modifier and Type | Method and Description |
---|---|
static <IN1,IN2> StreamMultipleInputProcessor |
StreamTwoInputProcessorFactory.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) |
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) |
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.