Modifier and Type | Class and Description |
---|---|
class |
CepOperator<IN,KEY,OUT>
CEP pattern operator for a keyed input stream.
|
Modifier and Type | Class and Description |
---|---|
class |
CompactCoordinatorStateHandler
Handler that processes the state of
CompactCoordinator when compaction is disabled. |
class |
CompactorOperator
An operator that perform compaction for the
FileSink . |
class |
CompactorOperatorStateHandler
Handler that processes the state of
CompactorOperator when compaction is disabled. |
Modifier and Type | Class and Description |
---|---|
class |
BatchCompactCoordinator
Coordinator for compaction in batch mode.
|
class |
BatchCompactOperator<T>
CompactOperator for compaction in batch mode.
|
class |
BatchFileWriter<T>
An operator for writing files in batch mode.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamingWriter<IN,OUT>
Operator for file system sink.
|
class |
PartitionCommitter
Committer operator for partitions.
|
class |
StreamingFileWriter<IN>
Writer for emitting
PartitionCommitInfo to downstream. |
Modifier and Type | Class and Description |
---|---|
class |
CompactCoordinator
This is the single (non-parallel) monitoring task which coordinate input files to compaction
units. - Receives in-flight input files inside checkpoint. - Receives all upstream end input
messages after the checkpoint completes successfully, starts coordination.
|
class |
CompactFileWriter<T>
Writer for emitting
CompactMessages.InputFile and CompactMessages.EndCheckpoint to downstream. |
class |
CompactOperator<T>
Receives compaction units to do compaction.
|
Modifier and Type | Class and Description |
---|---|
class |
KeyedTwoInputBroadcastProcessOperator<KEY,IN1,IN2,OUT>
Operator for
TwoInputBroadcastStreamProcessFunction in KeyedPartitionStream . |
class |
KeyedTwoInputNonBroadcastProcessOperator<KEY,IN1,IN2,OUT>
Operator for
TwoInputNonBroadcastStreamProcessFunction in KeyedPartitionStream . |
class |
KeyedTwoOutputProcessOperator<KEY,IN,OUT_MAIN,OUT_SIDE> |
class |
TwoInputBroadcastProcessOperator<IN1,IN2,OUT>
Operator for
TwoInputBroadcastStreamProcessFunction . |
class |
TwoInputNonBroadcastProcessOperator<IN1,IN2,OUT>
Operator for
TwoInputNonBroadcastStreamProcessFunction . |
class |
TwoOutputProcessOperator<IN,OUT_MAIN,OUT_SIDE>
Operator for
TwoOutputStreamProcessFunction . |
Modifier and Type | Class and Description |
---|---|
class |
BootstrapStreamTaskRunner<IN>
The runtime for a
BootstrapStreamTask . |
Modifier and Type | Class and Description |
---|---|
class |
StateBootstrapWrapperOperator<IN,OUT,OP extends AbstractStreamOperator<OUT> & OneInputStreamOperator<IN,OUT>>
Wraps an existing operator so it can be bootstrapped.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadcastStateBootstrapOperator<IN>
A
StreamOperator for executing BroadcastStateBootstrapFunction 's. |
class |
GroupReduceOperator<IN,OUT>
An operator for executing a
GroupReduceFunction on a bounded DataStream. |
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 | Class and Description |
---|---|
class |
AbstractUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined function.
|
class |
BatchGroupedReduceOperator<IN,KEY>
A
StreamOperator for executing a ReduceFunction on a KeyedStream in a RuntimeExecutionMode.BATCH
mode. |
class |
KeyedProcessOperator<K,IN,OUT>
A
StreamOperator for executing KeyedProcessFunctions . |
class |
LegacyKeyedProcessOperator<K,IN,OUT>
Deprecated.
Replaced by
KeyedProcessOperator which takes KeyedProcessFunction |
class |
MapPartitionOperator<IN,OUT>
The
MapPartitionOperator is used to process all records in each partition on non-keyed
stream. |
class |
PartitionAggregateOperator<IN,ACC,OUT>
The
PartitionAggregateOperator is used to apply the aggregate transformation on all
records of each partition. |
class |
PartitionReduceOperator<IN>
The
PartitionReduceOperator is used to apply the reduce transformation on all records of
each partition. |
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 |
StreamGroupedReduceOperator<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>>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Constructor and Description |
---|
StreamingRuntimeContext(AbstractStreamOperator<?> operator,
Environment env,
Map<String,Accumulator<?,?>> accumulators) |
Modifier and Type | Class and Description |
---|---|
class |
AsyncWaitOperator<IN,OUT>
The
AsyncWaitOperator allows to asynchronously process incoming stream records. |
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 | Class and Description |
---|---|
class |
AbstractPythonFunctionOperator<OUT>
Base class for all stream operators to execute Python functions.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractEmbeddedDataStreamPythonFunctionOperator<OUT>
Base class for all Python DataStream operators executed in embedded Python environment.
|
class |
AbstractEmbeddedPythonFunctionOperator<OUT>
Abstract class for all stream operators to execute Python functions in embedded Python
environment.
|
class |
AbstractOneInputEmbeddedPythonFunctionOperator<IN,OUT>
AbstractOneInputEmbeddedPythonFunctionOperator is responsible for run Python DataStream
operators with one input in Embedded Python environment. |
class |
AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT>
AbstractTwoInputEmbeddedPythonFunctionOperator is responsible for run Python DataStream
operators with two input user defined python function in Embedded Python environment. |
class |
EmbeddedPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT>
The
EmbeddedPythonBatchCoBroadcastProcessOperator is responsible for executing the Python
CoBroadcastProcess Function under BATCH mode, EmbeddedPythonCoProcessOperator is used
under STREAMING mode. |
class |
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator<K,IN1,IN2,OUT>
The
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator is responsible for executing the
Python CoBroadcastProcess function under BATCH mode, EmbeddedPythonKeyedCoProcessOperator
is used under STREAMING mode. |
class |
EmbeddedPythonCoProcessOperator<IN1,IN2,OUT>
EmbeddedPythonCoProcessOperator is responsible for executing Python CoProcessFunction in
embedded Python environment. |
class |
EmbeddedPythonKeyedCoProcessOperator<K,IN1,IN2,OUT>
EmbeddedPythonKeyedCoProcessOperator is responsible for executing user defined python
KeyedCoProcessFunction in embedded Python environment. |
class |
EmbeddedPythonKeyedProcessOperator<K,IN,OUT>
EmbeddedPythonKeyedProcessOperator is responsible for executing user defined python
KeyedProcessFunction in embedded Python environment. |
class |
EmbeddedPythonProcessOperator<IN,OUT>
EmbeddedPythonProcessOperator is responsible for executing Python ProcessFunction in
embedded Python environment. |
class |
EmbeddedPythonWindowOperator<K,IN,OUT,W extends Window>
EmbeddedPythonWindowOperator is responsible for executing user defined python
ProcessWindowFunction in embedded Python environment. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractExternalDataStreamPythonFunctionOperator<OUT>
Base class for all Python DataStream operators executed in Python process.
|
class |
AbstractExternalOneInputPythonFunctionOperator<IN,OUT>
AbstractExternalOneInputPythonFunctionOperator is responsible for launching beam runner
which will start a python harness to execute user defined python function. |
class |
AbstractExternalPythonFunctionOperator<OUT>
Abstract class for all stream operators to execute Python functions in external environment.
|
class |
AbstractExternalTwoInputPythonFunctionOperator<IN1,IN2,OUT>
AbstractExternalTwoInputPythonFunctionOperator is responsible for launching beam runner
which will start a python harness to execute two-input user defined python function. |
class |
ExternalPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT>
The
ExternalPythonBatchCoBroadcastProcessOperator is responsible for executing the Python
CoBroadcastProcess Function under BATCH mode, ExternalPythonCoProcessOperator is used
under STREAMING mode. |
class |
ExternalPythonBatchKeyedCoBroadcastProcessOperator<OUT>
The
ExternalPythonBatchKeyedCoBroadcastProcessOperator is responsible for executing the
Python CoBroadcastProcess function under BATCH mode, ExternalPythonKeyedCoProcessOperator
is used under STREAMING mode. |
class |
ExternalPythonCoProcessOperator<IN1,IN2,OUT>
The
ExternalPythonCoProcessOperator is responsible for executing the Python CoProcess
Function. |
class |
ExternalPythonKeyedCoProcessOperator<OUT>
ExternalPythonKeyedCoProcessOperator is responsible for launching beam runner which will
start a python harness to execute user defined python CoProcess function. |
class |
ExternalPythonKeyedProcessOperator<OUT>
ExternalPythonKeyedProcessOperator is responsible for launching beam runner which will
start a python harness to execute user defined python function. |
class |
ExternalPythonProcessOperator<IN,OUT>
ExternalPythonProcessOperator is responsible for launching beam runner which will start a
python harness to execute user defined python ProcessFunction. |
Modifier and Type | Class and Description |
---|---|
class |
KeyedSortPartitionOperator<INPUT,KEY>
The
KeyedSortPartitionOperator sorts records of a partition on KeyedStream . |
class |
SortPartitionOperator<INPUT>
The
SortPartitionOperator sorts records of a partition on non-keyed data stream. |
Modifier and Type | Class and Description |
---|---|
static class |
DelegateOperatorTransformation.DelegateOperator<OUT>
DelegateOperatorTransformation.DelegateOperator holds configurations, e.g. |
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 |
AbstractAsyncStateStreamOperator<OUT>
This operator is an abstract class that give the
AbstractStreamOperator the ability to
perform AsyncStateProcessing . |
class |
AbstractAsyncStateUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined function.
|
Modifier and Type | Class and Description |
---|---|
class |
EvictingWindowOperator<K,IN,OUT,W extends Window>
A
WindowOperator that also allows an Evictor to be used. |
Modifier and Type | Class and Description |
---|---|
static class |
CacheTransformationTranslator.IdentityStreamOperator<T>
The
CacheTransformationTranslator.IdentityStreamOperator acts as a dummy source to consume cached intermediate
dataset. |
static class |
CacheTransformationTranslator.NoOpStreamOperator<T>
The
CacheTransformationTranslator.NoOpStreamOperator acts as a dummy sink so that the upstream can produce the
intermediate dataset to be cached. |
Constructor and Description |
---|
ExecutionContextImpl(AbstractStreamOperator<?> operator,
RuntimeContext runtimeContext) |
Modifier and Type | Class and Description |
---|---|
class |
TableStreamOperator<OUT>
Table operator to invoke close always.
|
Modifier and Type | Class and Description |
---|---|
class |
LocalSlicingWindowAggOperator
The operator used for local window aggregation.
|
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 |
DynamicFilteringDataCollectorOperator
Operator to collect and build the
DynamicFilteringData for sources that supports dynamic
filtering. |
Modifier and Type | Class and Description |
---|---|
class |
HiveScriptTransformOperator
The operator for Hive's "transform xxx using 'script'".
|
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. 1.In most cases,
its performance is weaker than HashJoin. 2.It is more stable than HashJoin, and most of the data
can be sorted stably. 3.SortMergeJoin should be the best choice if sort can be omitted in the
case of multi-level join cascade with the same key.
|
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 |
MiniBatchStreamingJoinOperator
Streaming unbounded Join base operator which support mini-batch join.
|
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
The operator for temporal join (FOR SYSTEM_TIME AS OF o.rowtime) on row time, it has no
limitation about message types of the left input and right input, this means the operator deals
changelog well.
|
Modifier and Type | Class and Description |
---|---|
class |
WindowJoinOperator
Streaming window join operator.
|
Modifier and Type | Class and Description |
---|---|
class |
UnionStreamOperator
A special operator which collects all inputs' records and forwards them in
MultipleInputStreamOperatorBase . |
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 |
AbstractEmbeddedStatelessFunctionOperator
Base class for all stream operators to execute Python Stateless Functions in embedded Python
environment.
|
class |
AbstractOneInputPythonFunctionOperator<IN,OUT>
Base class for all one input stream operators to execute Python functions.
|
class |
AbstractStatelessFunctionOperator<IN,OUT,UDFIN>
Base class for all stream operators to execute Python Stateless Functions.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractPythonStreamAggregateOperator
Base class for
AbstractPythonStreamGroupAggregateOperator and PythonStreamGroupWindowAggregateOperator . |
class |
AbstractPythonStreamGroupAggregateOperator
Base class for
PythonStreamGroupAggregateOperator and PythonStreamGroupTableAggregateOperator . |
class |
PythonStreamGroupAggregateOperator
The Python AggregateFunction operator.
|
class |
PythonStreamGroupTableAggregateOperator
The Python TableAggregateFunction operator.
|
class |
PythonStreamGroupWindowAggregateOperator<K,W extends Window>
The Python Group Window AggregateFunction operator.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractArrowPythonAggregateFunctionOperator
The Abstract class of Arrow Aggregate Operator for Pandas
AggregateFunction . |
Modifier and Type | Class and Description |
---|---|
class |
BatchArrowPythonGroupAggregateFunctionOperator
The Batch Arrow Python
AggregateFunction Operator for Group Aggregation. |
class |
BatchArrowPythonGroupWindowAggregateFunctionOperator
The Batch Arrow Python
AggregateFunction Operator for Group Window Aggregation. |
class |
BatchArrowPythonOverWindowAggregateFunctionOperator
The Batch Arrow Python
AggregateFunction Operator for Over Window Aggregation. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamArrowPythonBoundedRangeOperator<K>
The Abstract class of Stream Arrow Python
AggregateFunction Operator for RANGE clause
bounded Over Window Aggregation. |
class |
AbstractStreamArrowPythonBoundedRowsOperator<K>
The Abstract class of Stream Arrow Python
AggregateFunction Operator for ROWS clause
bounded Over Window Aggregation. |
class |
AbstractStreamArrowPythonOverWindowAggregateFunctionOperator<K>
The Abstract class of Stream Arrow Python
AggregateFunction Operator for Over Window
Aggregation. |
class |
StreamArrowPythonGroupWindowAggregateFunctionOperator<K,W extends Window>
The Stream Arrow Python
AggregateFunction Operator for Group Window Aggregation. |
class |
StreamArrowPythonProcTimeBoundedRangeOperator<K>
The Stream Arrow Python
AggregateFunction Operator for ROWS clause proc-time bounded OVER
window. |
class |
StreamArrowPythonProcTimeBoundedRowsOperator<K>
The Stream Arrow Python
AggregateFunction Operator for ROWS clause proc-time bounded OVER
window. |
class |
StreamArrowPythonRowTimeBoundedRangeOperator<K>
The Stream Arrow Python
AggregateFunction Operator for RANGE clause event-time bounded
OVER window. |
class |
StreamArrowPythonRowTimeBoundedRowsOperator<K>
The Stream Arrow Python
AggregateFunction Operator for RANGE clause event-time bounded
OVER window. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPythonScalarFunctionOperator
Base class for all stream operators to execute Python
ScalarFunction s. |
class |
EmbeddedPythonScalarFunctionOperator
The Python
ScalarFunction operator in embedded Python environment. |
class |
PythonScalarFunctionOperator
The Python
ScalarFunction operator. |
Modifier and Type | Class and Description |
---|---|
class |
ArrowPythonScalarFunctionOperator
Arrow Python
ScalarFunction operator. |
Modifier and Type | Class and Description |
---|---|
class |
EmbeddedPythonTableFunctionOperator
The Python
TableFunction operator in embedded Python environment. |
class |
PythonTableFunctionOperator
The Python
TableFunction operator. |
Modifier and Type | Class and Description |
---|---|
class |
GlobalRuntimeFilterBuilderOperator
Global runtime filter builder operator.
|
class |
LocalRuntimeFilterBuilderOperator
Local runtime filter builder operator.
|
Modifier and Type | Class and Description |
---|---|
class |
ConstraintEnforcer
Processes
RowData to enforce the following constraints:
NOT NULL column constraint of a sink table
CHAR(length) /@{code VARCHAR(length)}: trim string values to comply with the length defined in their corresponding types. |
class |
OutputConversionOperator
Operator that converts to external data structures and unwraps atomic records if necessary.
|
class |
RowKindSetter
An operator that sets the row kind of the incoming records to a specific row kind.
|
class |
SinkOperator
A
StreamOperator for executing SinkFunctions . |
class |
SinkUpsertMaterializer
An operator that maintains incoming records in state corresponding to the upsert keys and
generates an upsert view for the downstream operator.
|
class |
StreamRecordTimestampInserter
Operator which sets the timestamp on the StreamRecord from the corresponding column of each row.
|
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 |
InputConversionOperator<E>
Operator that converts to internal data structures and wraps atomic records if necessary.
|
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. |
class |
WindowOperator<K,W extends Window>
An operator that implements the logic for windowing based on a
GroupWindowAssigner and
Trigger . |
Modifier and Type | Class and Description |
---|---|
class |
WindowAggOperator<K,W>
We divide windows into 2 categories: Aligned Windows and Unaligned Windows.
|
Modifier and Type | Class and Description |
---|---|
class |
AlignedWindowTableFunctionOperator
The operator for aligned window table function.
|
class |
UnalignedWindowTableFunctionOperator
The operator for unaligned window table function.
|
class |
WindowTableFunctionOperatorBase
The
WindowTableFunctionOperatorBase acts as a table-valued function to assign windows for
input row. |
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.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.