Uses of Interface
org.apache.flink.runtime.jobgraph.tasks.TaskInvokable
-
-
Uses of TaskInvokable in org.apache.flink.runtime.iterative.task
Classes in org.apache.flink.runtime.iterative.task that implement TaskInvokable 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 TaskInvokable in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph that return types with arguments of type TaskInvokable Modifier and Type Method Description Class<? extends TaskInvokable>
JobVertex. getInvokableClass(ClassLoader cl)
Returns the invokable class which represents the task of this vertex.Method parameters in org.apache.flink.runtime.jobgraph with type arguments of type TaskInvokable Modifier and Type Method Description void
JobVertex. setInvokableClass(Class<? extends TaskInvokable> invokable)
-
Uses of TaskInvokable in org.apache.flink.runtime.jobgraph.tasks
Classes in org.apache.flink.runtime.jobgraph.tasks that implement TaskInvokable Modifier and Type Class Description class
AbstractInvokable
A base implementation ofTaskInvokable
,CheckpointableTask
, andCoordinatedTask
with most methods throwingUnsupportedOperationException
or doing nothing. -
Uses of TaskInvokable in org.apache.flink.runtime.operators
Classes in org.apache.flink.runtime.operators that implement TaskInvokable 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 TaskInvokable in org.apache.flink.runtime.operators.sort
Methods in org.apache.flink.runtime.operators.sort with parameters of type TaskInvokable Modifier and Type Method Description static <E> ExternalSorterBuilder<E>
ExternalSorter. newBuilder(MemoryManager memoryManager, TaskInvokable parentTask, org.apache.flink.api.common.typeutils.TypeSerializer<E> serializer, org.apache.flink.api.common.typeutils.TypeComparator<E> comparator, org.apache.flink.api.common.ExecutionConfig executionConfig)
Creates a builder for theExternalSorter
.Constructors in org.apache.flink.runtime.operators.sort with parameters of type TaskInvokable Constructor Description LargeRecordHandler(org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer, org.apache.flink.api.common.typeutils.TypeComparator<T> comparator, IOManager ioManager, MemoryManager memManager, List<org.apache.flink.core.memory.MemorySegment> memory, TaskInvokable memoryOwner, int maxFilehandles, org.apache.flink.api.common.ExecutionConfig executionConfig)
-
Uses of TaskInvokable in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return types with arguments of type TaskInvokable Modifier and Type Method Description Class<? extends TaskInvokable>
StreamNode. getJobVertexClass()
Method parameters in org.apache.flink.streaming.api.graph with type arguments of type TaskInvokable Modifier and Type Method Description protected StreamNode
StreamGraph. addNode(Integer vertexID, String slotSharingGroup, String coLocationGroup, Class<? extends TaskInvokable> vertexClass, StreamOperatorFactory<?> operatorFactory, String operatorName)
Constructor parameters in org.apache.flink.streaming.api.graph with type arguments of type TaskInvokable Constructor 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)
-
Uses of TaskInvokable in org.apache.flink.streaming.api.operators.sort
Methods in org.apache.flink.streaming.api.operators.sort with parameters of type TaskInvokable Modifier and Type Method Description static <K> MultiInputSortingDataInput.SelectableSortingInputs
MultiInputSortingDataInput. wrapInputs(TaskInvokable containingTask, StreamTaskInput<Object>[] sortingInputs, org.apache.flink.api.java.functions.KeySelector<Object,K>[] keySelectors, org.apache.flink.api.common.typeutils.TypeSerializer<Object>[] inputSerializers, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, StreamTaskInput<Object>[] passThroughInputs, MemoryManager memoryManager, IOManager ioManager, boolean objectReuse, double managedMemoryFraction, org.apache.flink.configuration.Configuration taskManagerConfiguration, org.apache.flink.api.common.ExecutionConfig executionConfig)
Constructors in org.apache.flink.streaming.api.operators.sort with parameters of type TaskInvokable Constructor Description SortingDataInput(StreamTaskInput<T> wrappedInput, org.apache.flink.api.common.typeutils.TypeSerializer<T> typeSerializer, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, org.apache.flink.api.java.functions.KeySelector<T,K> keySelector, MemoryManager memoryManager, IOManager ioManager, boolean objectReuse, double managedMemoryFraction, org.apache.flink.configuration.Configuration taskManagerConfiguration, TaskInvokable containingTask, org.apache.flink.api.common.ExecutionConfig executionConfig)
-
Uses of TaskInvokable in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type TaskInvokable Modifier and Type Method Description static StreamMultipleInputProcessor
StreamMultipleInputProcessorFactory. create(TaskInvokable ownerTask, CheckpointedInputGate[] checkpointedInputGates, StreamConfig.InputConfig[] configuredInputs, IOManager ioManager, MemoryManager memoryManager, TaskIOMetricGroup ioMetricGroup, org.apache.flink.metrics.Counter mainOperatorRecordsIn, MultipleInputStreamOperator<?> mainOperator, WatermarkGauge[] inputWatermarkGauges, StreamConfig streamConfig, org.apache.flink.configuration.Configuration taskManagerConfig, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.api.common.ExecutionConfig executionConfig, ClassLoader userClassloader, OperatorChain<?,?> operatorChain, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, org.apache.flink.api.common.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, org.apache.flink.configuration.Configuration taskManagerConfig, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.api.common.ExecutionConfig executionConfig, ClassLoader userClassloader, org.apache.flink.metrics.Counter numRecordsIn, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, org.apache.flink.api.common.TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
-
Uses of TaskInvokable in org.apache.flink.streaming.runtime.tasks
Classes in org.apache.flink.streaming.runtime.tasks that implement TaskInvokable 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.
-