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 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 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 voidJobVertex. 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 classAbstractInvokableA base implementation ofTaskInvokable,CheckpointableTask, andCoordinatedTaskwith most methods throwingUnsupportedOperationExceptionor 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 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 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 StreamNodeStreamGraph. 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.SelectableSortingInputsMultiInputSortingDataInput. 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 StreamMultipleInputProcessorStreamMultipleInputProcessorFactory. 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 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.
-