Uses of Class
org.apache.flink.streaming.runtime.tasks.StreamTask
-
Packages that use StreamTask Package Description org.apache.flink.cep.operator org.apache.flink.runtime.asyncprocessing.operators org.apache.flink.state.api.output.operators org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.async org.apache.flink.streaming.api.operators.sortpartition org.apache.flink.streaming.runtime.operators.windowing This package contains the operators that implement the various window operations on data streams.org.apache.flink.streaming.runtime.tasks This package contains classes that realize streaming tasks.org.apache.flink.table.runtime.operators.fusion org.apache.flink.table.runtime.operators.join -
-
Uses of StreamTask in org.apache.flink.cep.operator
Methods in org.apache.flink.cep.operator with parameters of type StreamTask Modifier and Type Method Description protected void
CepOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)
-
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 void
AbstractAsyncStateUdfStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)
-
Uses of StreamTask in org.apache.flink.state.api.output.operators
Methods in org.apache.flink.state.api.output.operators with parameters of type StreamTask Modifier and Type Method Description void
StateBootstrapWrapperOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<TaggedOperatorSubtaskState>> 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>>
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 void
AbstractStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)
protected void
AbstractUdfStreamOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)
protected void
SourceOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)
static <OUT> void
StreamOperatorUtils. 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, MailboxExecutor mailboxExecutor)
-
Uses of StreamTask in org.apache.flink.streaming.api.operators.async
Methods in org.apache.flink.streaming.api.operators.async with parameters of type StreamTask Modifier and Type Method Description protected void
AsyncWaitOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<OUT>> output)
-
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 void
KeyedSortPartitionOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<INPUT>> output)
protected void
SortPartitionOperator. setup(StreamTask<?,?> containingTask, StreamConfig config, Output<StreamRecord<INPUT>> 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 void
WindowOperator. 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 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
TwoInputStreamTask<IN1,IN2,OUT>
AStreamTask
for executing aTwoInputStreamOperator
and supporting theTwoInputStreamOperator
to 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)
-
Uses of StreamTask in org.apache.flink.table.runtime.operators.fusion
Methods in org.apache.flink.table.runtime.operators.fusion that return StreamTask Modifier and Type Method Description StreamTask<?,?>
FusionStreamOperatorBase. getContainingTask()
-
Uses of StreamTask in org.apache.flink.table.runtime.operators.join
Methods in org.apache.flink.table.runtime.operators.join with parameters of type StreamTask Modifier and Type Method Description void
SortMergeJoinFunction. open(boolean adaptiveHashJoin, StreamTask<?,?> taskContainer, StreamConfig operatorConfig, StreamRecordCollector collector, long totalMemory, RuntimeContext runtimeContext, OperatorMetricGroup operatorMetricGroup)
-