Modifier and Type | Class and Description |
---|---|
class |
CepOperator<IN,KEY,OUT>
CEP pattern operator for a keyed input stream.
|
Modifier and Type | Method and Description |
---|---|
StreamOperator<TaggedOperatorSubtaskState> |
SavepointWriterOperatorFactory.createOperator(long savepointTimestamp,
Path savepointPath)
Creates a
StreamOperator to be used for generating and snapshotting state. |
Modifier and Type | Method and Description |
---|---|
static <OUT,OP extends StreamOperator<OUT>> |
SnapshotUtils.snapshot(OP operator,
int index,
long timestamp,
boolean isExactlyOnceMode,
boolean isUnalignedCheckpoint,
CheckpointStorageWorkerView checkpointStorage,
Path savepointPath) |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastStateBootstrapOperator<IN>
A
StreamOperator for executing BroadcastStateBootstrapFunction 's. |
class |
KeyedStateBootstrapOperator<K,IN>
A
StreamOperator for executing KeyedStateBootstrapFunction 's. |
class |
StateBootstrapOperator<IN>
A
StreamOperator for executing StateBootstrapFunction 's. |
Modifier and Type | Class and Description |
---|---|
class |
QueryableAppendingStateOperator<IN>
Internal operator handling queryable AppendingState instances.
|
class |
QueryableValueStateOperator<IN>
Internal operator handling queryable ValueState instances.
|
Modifier and Type | Class and Description |
---|---|
class |
ContinuousFileReaderOperator<OUT,T extends TimestampedInputSplit>
The operator that reads the
splits received from the preceding
ContinuousFileMonitoringFunction . |
Modifier and Type | Method and Description |
---|---|
<O extends StreamOperator<OUT>> |
ContinuousFileReaderOperatorFactory.createStreamOperator(StreamOperatorParameters<OUT> parameters) |
Modifier and Type | Method and Description |
---|---|
Class<? extends StreamOperator> |
ContinuousFileReaderOperatorFactory.getStreamOperatorClass(ClassLoader classLoader) |
Modifier and Type | Method and Description |
---|---|
<T extends StreamOperator<?>> |
StreamConfig.getStreamOperator(ClassLoader cl) |
Modifier and Type | Method and Description |
---|---|
StreamOperator<?> |
StreamNode.getOperator() |
Modifier and Type | Method and Description |
---|---|
void |
StreamConfig.setStreamOperator(StreamOperator<?> operator) |
Constructor and Description |
---|
StreamNode(Integer id,
String slotSharingGroup,
String coLocationGroup,
StreamOperator<?> operator,
String operatorName,
List<OutputSelector<?>> outputSelector,
Class<? extends AbstractInvokable> jobVertexClass) |
Modifier and Type | Interface and Description |
---|---|
interface |
MultipleInputStreamOperator<OUT>
Interface for stream operators with multiple
Input s. |
interface |
OneInputStreamOperator<IN,OUT>
Interface for stream operators with one input.
|
interface |
TwoInputStreamOperator<IN1,IN2,OUT>
Interface for stream operators with two inputs.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamOperator<OUT>
Base class for all stream operators.
|
class |
AbstractStreamOperatorV2<OUT>
New base class for all stream operators, intended to eventually replace
AbstractStreamOperator . |
class |
AbstractUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined function.
|
class |
KeyedProcessOperator<K,IN,OUT>
A
StreamOperator for executing KeyedProcessFunctions . |
class |
LegacyKeyedProcessOperator<K,IN,OUT>
Deprecated.
Replaced by
KeyedProcessOperator which takes KeyedProcessFunction |
class |
ProcessOperator<IN,OUT>
A
StreamOperator for executing ProcessFunctions . |
class |
SourceOperator<OUT,SplitT extends SourceSplit>
Base source operator only used for integrating the source reader which is proposed by FLIP-27.
|
class |
StreamFilter<IN>
A
StreamOperator for executing FilterFunctions . |
class |
StreamFlatMap<IN,OUT>
A
StreamOperator for executing FlatMapFunctions . |
class |
StreamGroupedFold<IN,OUT,KEY>
Deprecated.
will be removed in a future version
|
class |
StreamGroupedReduce<IN>
|
class |
StreamMap<IN,OUT>
A
StreamOperator for executing MapFunctions . |
class |
StreamProject<IN,OUT extends Tuple>
A
StreamOperator for executing projections on streams. |
class |
StreamSink<IN>
A
StreamOperator for executing SinkFunctions . |
class |
StreamSource<OUT,SRC extends SourceFunction<OUT>>
StreamOperator for streaming sources. |
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.
|
<T extends StreamOperator<OUT>> |
StreamOperatorFactory.createStreamOperator(StreamOperatorParameters<OUT> parameters)
Create the operator.
|
<T extends StreamOperator<OUT>> |
SourceOperatorFactory.createStreamOperator(StreamOperatorParameters<OUT> parameters) |
<T extends StreamOperator<OUT>> |
SimpleOperatorFactory.createStreamOperator(StreamOperatorParameters<OUT> parameters) |
<T extends StreamOperator<OUT>> |
CoordinatedOperatorFactory.createStreamOperator(StreamOperatorParameters<OUT> parameters)
The implementation should return an instance of
OperatorEventHandler . |
Modifier and Type | Method and Description |
---|---|
StreamOperator<OUT> |
SimpleOperatorFactory.getOperator() |
Modifier and Type | Method and Description |
---|---|
Class<? extends StreamOperator> |
StreamOperatorFactory.getStreamOperatorClass(ClassLoader classLoader)
Returns the runtime class of the stream operator.
|
Class<? extends StreamOperator> |
SourceOperatorFactory.getStreamOperatorClass(ClassLoader classLoader) |
Class<? extends StreamOperator> |
SimpleOperatorFactory.getStreamOperatorClass(ClassLoader classLoader) |
Modifier and Type | Method and Description |
---|---|
static <OUT> SimpleOperatorFactory<OUT> |
SimpleOperatorFactory.of(StreamOperator<OUT> operator)
Create a SimpleOperatorFactory from existed StreamOperator.
|
Constructor and Description |
---|
SimpleOperatorFactory(StreamOperator<OUT> operator) |
Modifier and Type | Class and Description |
---|---|
class |
AsyncWaitOperator<IN,OUT>
The
AsyncWaitOperator allows to asynchronously process incoming stream records. |
Modifier and Type | Method and Description |
---|---|
<T extends StreamOperator<OUT>> |
AsyncWaitOperatorFactory.createStreamOperator(StreamOperatorParameters<OUT> parameters) |
Modifier and Type | Method and Description |
---|---|
Class<? extends StreamOperator> |
AsyncWaitOperatorFactory.getStreamOperatorClass(ClassLoader classLoader) |
Modifier and Type | Class and Description |
---|---|
class |
CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT>
A
TwoInputStreamOperator for executing KeyedBroadcastProcessFunctions . |
class |
CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT>
A
TwoInputStreamOperator for executing BroadcastProcessFunctions . |
class |
CoProcessOperator<IN1,IN2,OUT>
A
StreamOperator for executing CoProcessFunctions . |
class |
CoStreamFlatMap<IN1,IN2,OUT>
StreamOperator for processing CoFlatMapFunctions . |
class |
CoStreamMap<IN1,IN2,OUT>
StreamOperator for processing CoMapFunctions . |
class |
IntervalJoinOperator<K,T1,T2,OUT>
An
operator to execute time-bounded stream inner joins. |
class |
KeyedCoProcessOperator<K,IN1,IN2,OUT>
A
StreamOperator for executing keyed KeyedCoProcessFunction . |
class |
LegacyKeyedCoProcessOperator<K,IN1,IN2,OUT>
Deprecated.
Replaced by
KeyedCoProcessOperator which takes KeyedCoProcessFunction |
Modifier and Type | Class and Description |
---|---|
class |
CollectSinkOperator<IN>
A
StreamSink that collects query results and sends them back to the client. |
Modifier and Type | Method and Description |
---|---|
<T extends StreamOperator<Object>> |
CollectSinkOperatorFactory.createStreamOperator(StreamOperatorParameters<Object> parameters) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPythonFunctionOperator<IN,OUT>
Base class for all stream operators to execute Python functions.
|
Modifier and Type | Class and Description |
---|---|
class |
CassandraRowWriteAheadSink
Sink that emits its input elements into a Cassandra table.
|
class |
CassandraTupleWriteAheadSink<IN extends Tuple>
Sink that emits its input elements into a Cassandra database.
|
Modifier and Type | Class and Description |
---|---|
class |
GenericWriteAheadSink<IN>
Generic Sink that emits its input elements into an arbitrary backend.
|
class |
TimestampsAndWatermarksOperator<T>
A stream operator that may do one or both of the following: extract timestamps from events and
generate watermarks.
|
Modifier and Type | Class and Description |
---|---|
class |
EvictingWindowOperator<K,IN,OUT,W extends Window>
A
WindowOperator that also allows an Evictor to be used. |
class |
WindowOperator<K,IN,ACC,OUT,W extends Window>
An operator that implements the logic for windowing based on a
WindowAssigner and Trigger . |
Modifier and Type | Class and Description |
---|---|
class |
OperatorChain<OUT,OP extends StreamOperator<OUT>>
The
OperatorChain contains all operators that are executed as one chain within a single
StreamTask . |
class |
StreamOperatorWrapper<OUT,OP extends StreamOperator<OUT>>
This class handles the close, endInput and other related logic of a
StreamOperator . |
class |
StreamTask<OUT,OP extends StreamOperator<OUT>>
Base class for all streaming tasks.
|
Modifier and Type | Field and Description |
---|---|
protected OP |
StreamTask.headOperator
the head operator that consumes the input streams of this task.
|
Modifier and Type | Method and Description |
---|---|
protected Counter |
StreamTask.setupNumRecordsInCounter(StreamOperator streamOperator) |
Modifier and Type | Class and Description |
---|---|
class |
StreamingFileCommitter
Committer for
StreamingFileWriter . |
class |
StreamingFileWriter
Operator for file system sink.
|
Modifier and Type | Class and Description |
---|---|
class |
GeneratedOperator<C extends StreamOperator<?>>
Describes a generated
StreamOperator . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractProcessStreamOperator<OUT>
AbstractProcessStreamOperator is a base class for stream operators without key.
|
class |
TableStreamOperator<OUT>
Table operator to invoke close always.
|
Modifier and Type | Method and Description |
---|---|
<T extends StreamOperator<OUT>> |
CodeGenOperatorFactory.createStreamOperator(StreamOperatorParameters<OUT> parameters) |
Modifier and Type | Method and Description |
---|---|
GeneratedClass<? extends StreamOperator<OUT>> |
CodeGenOperatorFactory.getGeneratedClass() |
Class<? extends StreamOperator> |
CodeGenOperatorFactory.getStreamOperatorClass(ClassLoader classLoader) |
Constructor and Description |
---|
CodeGenOperatorFactory(GeneratedClass<? extends StreamOperator<OUT>> generatedClass) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMapBundleOperator<K,V,IN,OUT>
The
AbstractMapBundleOperator simply used a java Map to store the input elements in
key-value form. |
class |
KeyedMapBundleOperator<K,V,IN,OUT>
The
KeyedMapBundleOperator uses framework's key as bundle map key, thus can only be used
on KeyedStream . |
class |
MapBundleOperator<K,V,IN,OUT>
The
MapBundleOperator uses a KeySelector to extract bundle key, thus can be used
with non-keyed-stream. |
Modifier and Type | Class and Description |
---|---|
class |
HashJoinOperator
Hash join base operator.
|
class |
KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT>
A
KeyedCoProcessOperator that supports holding back watermarks with a static delay. |
class |
SortMergeJoinOperator
An implementation that realizes the joining through a sort-merge join strategy.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamingJoinOperator
Abstract implementation for streaming unbounded Join operator which defines some member fields
can be shared between different implementations.
|
class |
StreamingJoinOperator
Streaming unbounded Join operator which supports INNER/LEFT/RIGHT/FULL JOIN.
|
class |
StreamingSemiAntiJoinOperator
Streaming unbounded Join operator which supports SEMI/ANTI JOIN.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseTwoInputStreamOperatorWithStateRetention
An abstract
TwoInputStreamOperator that allows its subclasses to clean up their state
based on a TTL. |
class |
TemporalProcessTimeJoinOperator
The operator to temporal join a stream on processing time.
|
class |
TemporalRowTimeJoinOperator
This operator works by keeping on the state collection of probe and build records to process on
next watermark.
|
Modifier and Type | Class and Description |
---|---|
class |
BufferDataOverWindowOperator
the operator for OVER window need cache data by ResettableExternalBuffer for
OverWindowFrame . |
class |
NonBufferOverWindowOperator
The operator for OVER window don't need cache data.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractStatelessFunctionOperator<IN,OUT,UDFIN>
Base class for all stream operators to execute Python Stateless Functions.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractPythonScalarFunctionOperator<IN,OUT,UDFIN>
Base class for all stream operators to execute Python
ScalarFunction s. |
class |
AbstractRowDataPythonScalarFunctionOperator
The Python
ScalarFunction operator for the blink planner. |
class |
AbstractRowPythonScalarFunctionOperator
Base Python
ScalarFunction operator for the legacy planner. |
class |
PythonScalarFunctionOperator
The Python
ScalarFunction operator for the legacy planner. |
class |
RowDataPythonScalarFunctionOperator
The Python
ScalarFunction operator for the blink planner. |
Modifier and Type | Class and Description |
---|---|
class |
ArrowPythonScalarFunctionOperator
Arrow Python
ScalarFunction operator for the old planner. |
class |
RowDataArrowPythonScalarFunctionOperator
Arrow Python
ScalarFunction operator for the blink planner. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPythonTableFunctionOperator<IN,OUT,UDTFIN> |
class |
PythonTableFunctionOperator
The Python
TableFunction operator for the legacy planner. |
class |
RowDataPythonTableFunctionOperator
The Python
TableFunction operator for the blink planner. |
Modifier and Type | Class and Description |
---|---|
class |
SinkOperator
A
StreamOperator for executing SinkFunctions . |
Modifier and Type | Class and Description |
---|---|
class |
LimitOperator
Operator for batch limit.
|
class |
ProcTimeSortOperator
Sort on proc-time and additional secondary sort attributes.
|
class |
RankOperator
Rank operator to compute top N.
|
class |
RowTimeSortOperator
Sort based on event-time and possibly additional secondary sort attributes.
|
class |
SortLimitOperator
Operator for batch sort limit.
|
class |
SortOperator
Operator for batch sort.
|
class |
StreamSortOperator
Operator for stream sort.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregateWindowOperator<K,W extends Window>
A
WindowOperator for grouped window aggregates. |
class |
TableAggregateWindowOperator<K,W extends Window>
A
WindowOperator for grouped and windowed table aggregates. |
Modifier and Type | Class and Description |
---|---|
class |
ProcTimeMiniBatchAssignerOperator
A stream operator that emits mini-batch marker in a given period.
|
class |
RowTimeMiniBatchAssginerOperator
A stream operator that emits watermark in a given event-time interval.
|
class |
WatermarkAssignerOperator
A stream operator that extracts timestamps from stream elements and generates periodic
watermarks.
|
Modifier and Type | Method and Description |
---|---|
StreamOperator |
WatermarkAssignerOperatorFactory.createStreamOperator(StreamOperatorParameters initializer) |
Modifier and Type | Method and Description |
---|---|
Class<? extends StreamOperator> |
WatermarkAssignerOperatorFactory.getStreamOperatorClass(ClassLoader classLoader) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.