Package | Description |
---|---|
org.apache.flink.cep.operator | |
org.apache.flink.state.api.output.operators | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.async | |
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 |
Modifier and Type | Method and Description |
---|---|
void |
CepOperator.setup(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<OUT>> output) |
Modifier and Type | Method and Description |
---|---|
void |
StateBootstrapWrapperOperator.setup(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<TaggedOperatorSubtaskState>> output) |
Modifier and Type | Method and Description |
---|---|
StreamTask<?,?> |
StreamOperatorParameters.getContainingTask() |
StreamTask<?,?> |
AbstractStreamOperator.getContainingTask() |
Modifier and Type | Method and Description |
---|---|
static <OUT,OP extends StreamOperator<OUT>> |
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.
|
void |
SourceOperator.setup(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<OUT>> output) |
void |
SetupableStreamOperator.setup(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<OUT>> output)
Deprecated.
Initializes the operator.
|
void |
AbstractUdfStreamOperator.setup(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<OUT>> output) |
void |
AbstractStreamOperator.setup(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<OUT>> output) |
Constructor and Description |
---|
StreamOperatorParameters(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<OUT>> output,
Supplier<ProcessingTimeService> processingTimeServiceFactory,
OperatorEventDispatcher operatorEventDispatcher) |
Modifier and Type | Method and Description |
---|---|
void |
AsyncWaitOperator.setup(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<OUT>> output) |
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 |
TwoInputStreamTask<IN1,IN2,OUT>
A
StreamTask for executing a TwoInputStreamOperator and supporting the TwoInputStreamOperator to select input for reading. |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
StreamTask<?,?> |
FusionStreamOperatorBase.getContainingTask() |
Modifier and Type | Method and Description |
---|---|
void |
SortMergeJoinFunction.open(boolean adaptiveHashJoin,
StreamTask<?,?> taskContainer,
StreamConfig operatorConfig,
StreamRecordCollector collector,
long totalMemory,
RuntimeContext runtimeContext,
OperatorMetricGroup operatorMetricGroup) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.