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 |
CompactCoordinator
Coordinator that coordinates file compaction for the
FileSink . |
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 |
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 |
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 |
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. |
class |
StateBootstrapWrapperOperator<IN,OUT,OP extends AbstractStreamOperator<OUT> & OneInputStreamOperator<IN,OUT>>
Wraps an existing operator so it can be bootstrapped.
|
Modifier and Type | Method and Description |
---|---|
<R> SingleOutputStreamOperator<R> |
DataStream.transform(String operatorName,
TypeInformation<R> outTypeInfo,
OneInputStreamOperator<T,R> operator)
Method for passing user defined operators along with the type information that will transform
the DataStream.
|
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 |
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 |
ProcessOperator<IN,OUT>
A
StreamOperator for executing ProcessFunctions . |
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 . |
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 |
PythonKeyedProcessOperator<OUT>
PythonKeyedProcessOperator is responsible for launching beam runner which will start a
python harness to execute user defined python function. |
class |
PythonProcessOperator<IN,OUT>
PythonProcessOperator is responsible for launching beam runner which will start a python
harness to execute user defined python ProcessFunction. |
Modifier and Type | Method and Description |
---|---|
OneInputStreamOperator<IN,OUT> |
OneInputTransformation.getOperator() |
Constructor and Description |
---|
OneInputTransformation(Transformation<IN> input,
String name,
OneInputStreamOperator<IN,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
OneInputTransformation from the given input and operator. |
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 |
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 |
UnionStreamOperator
A special operator which collects all inputs' records and forwards them in
MultipleInputStreamOperatorBase . |
Constructor and Description |
---|
OneInput(OneInputStreamOperator<RowData,RowData> operator) |
Constructor and Description |
---|
CopyingOneInputStreamOperatorOutput(OneInputStreamOperator<RowData,RowData> operator,
TypeSerializer<RowData> serializer) |
OneInputStreamOperatorOutput(OneInputStreamOperator<RowData,RowData> operator) |
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 |
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 |
PythonTableFunctionOperator
The Python
TableFunction 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 |
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 |
WindowTableFunctionOperator
The operator acts as a table-valued function to assign windows for input row.
|
Modifier and Type | Class and Description |
---|---|
class |
SlicingWindowOperator<K,W>
The
SlicingWindowOperator implements an optimized processing for aligned windows which
can apply the slicing optimization. |
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–2023 The Apache Software Foundation. All rights reserved.