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 |
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>
The operator that reads the
splits received from the preceding
ContinuousFileMonitoringFunction . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamOperator<OUT>
Base class for all stream operators.
|
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 |
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 | Class and Description |
---|---|
class |
AsyncWaitOperator<IN,OUT>
The
AsyncWaitOperator allows to asynchronously process incoming stream records. |
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 |
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 |
ExtractTimestampsOperator<T>
Deprecated.
|
class |
GenericWriteAheadSink<IN>
Generic Sink that emits its input elements into an arbitrary backend.
|
class |
TimestampsAndPeriodicWatermarksOperator<T>
A stream operator that extracts timestamps from stream elements and
generates periodic watermarks.
|
class |
TimestampsAndPunctuatedWatermarksOperator<T>
A stream operator that extracts timestamps from stream elements and
generates watermarks based on punctuation elements.
|
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 |
AbstractProcessStreamOperator<OUT>
AbstractProcessStreamOperator is a base class for stream operators without key.
|
class |
TableStreamOperator<OUT>
Table operator to invoke close always.
|
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 |
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 |
MiniBatchAssignerOperator
A stream operator that emits mini-batch marker in a given period.
|
class |
MiniBatchedWatermarkAssignerOperator
A stream operator that extracts timestamps from stream elements and
generates watermarks with specified emit latency.
|
class |
WatermarkAssignerOperator
A stream operator that extracts timestamps from stream elements and
generates periodic watermarks.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.