Uses of Class
org.apache.flink.streaming.runtime.tasks.StreamTask
-
-
Uses of StreamTask in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators with parameters of type StreamTask Modifier and Type Method Description protected voidAbstractAsyncStateUdfStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output) -
Uses of StreamTask in org.apache.flink.runtime.asyncprocessing.operators.windowing
Methods in org.apache.flink.runtime.asyncprocessing.operators.windowing with parameters of type StreamTask Modifier and Type Method Description voidAsyncWindowOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output) -
Uses of StreamTask in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return StreamTask Modifier and Type Method Description StreamTask<?,?>AbstractStreamOperator. getContainingTask()StreamTask<?,?>StreamOperatorParameters. getContainingTask()Methods in org.apache.flink.streaming.api.operators with parameters of type StreamTask Modifier and Type Method Description static <OUT,OP extends StreamOperator<OUT>>
org.apache.flink.api.java.tuple.Tuple2<OP,Optional<ProcessingTimeService>>StreamOperatorFactoryUtil. createOperator(StreamOperatorFactory<OUT> operatorFactory, StreamTask<OUT,?> containingTask, StreamConfig configuration, Output<StreamRecord<OUT>> output, OperatorEventDispatcher operatorEventDispatcher)Creates a new operator using a factory and makes sure that all special factory traits are properly handled.protected voidAbstractStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)protected voidAbstractUdfStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)protected voidSourceOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)static <OUT> voidStreamOperatorUtils. setupStreamOperator(AbstractStreamOperator<OUT> operator, StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)Constructors in org.apache.flink.streaming.api.operators with parameters of type StreamTask Constructor Description StreamOperatorParameters(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output, Supplier<ProcessingTimeService> processingTimeServiceFactory, OperatorEventDispatcher operatorEventDispatcher, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor) -
Uses of StreamTask in org.apache.flink.streaming.api.operators.sortpartition
Methods in org.apache.flink.streaming.api.operators.sortpartition with parameters of type StreamTask Modifier and Type Method Description protected voidKeyedSortPartitionOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<INPUT>> output)protected voidSortPartitionOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<INPUT>> output) -
Uses of StreamTask in org.apache.flink.streaming.runtime.operators.sink
Methods in org.apache.flink.streaming.runtime.operators.sink with parameters of type StreamTask Modifier and Type Method Description protected voidGlobalCommitterOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<Void>> output) -
Uses of StreamTask in org.apache.flink.streaming.runtime.operators.windowing
Methods in org.apache.flink.streaming.runtime.operators.windowing with parameters of type StreamTask Modifier and Type Method Description voidWindowOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output) -
Uses of StreamTask in org.apache.flink.streaming.runtime.tasks
Subclasses of StreamTask in org.apache.flink.streaming.runtime.tasks 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.classTwoInputStreamTask<IN1,IN2,OUT>AStreamTaskfor executing aTwoInputStreamOperatorand supporting theTwoInputStreamOperatorto select input for reading.Constructors in org.apache.flink.streaming.runtime.tasks with parameters of type StreamTask Constructor Description FinishedOperatorChain(StreamTask<OUT,OP> containingTask, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate)OperatorChain(StreamTask<OUT,OP> containingTask, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate)RegularOperatorChain(StreamTask<OUT,OP> containingTask, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate)
-