Package | Description |
---|---|
org.apache.flink.cep.operator | |
org.apache.flink.streaming.api.functions.source | |
org.apache.flink.streaming.api.functions.windowing | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.async | |
org.apache.flink.streaming.api.operators.co | |
org.apache.flink.streaming.runtime.operators |
This package contains the operators that perform the stream transformations.
|
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations
on data streams.
|
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 |
ContinuousFileReaderOperator<OUT>
The operator that reads the
splits received from the preceding
ContinuousFileMonitoringFunction . |
Modifier and Type | Class and Description |
---|---|
class |
FoldApplyAllWindowFunction<W extends Window,T,ACC,R>
Deprecated.
will be removed in a future version
|
class |
FoldApplyProcessAllWindowFunction<W extends Window,T,ACC,R>
Deprecated.
will be removed in a future version
|
class |
FoldApplyProcessWindowFunction<K,W extends Window,T,ACC,R>
Deprecated.
will be removed in a future version
|
class |
FoldApplyWindowFunction<K,W extends Window,T,ACC,R>
Deprecated.
will be removed in a future version
|
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 |
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 |
StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction>
|
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 |
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
CoProcessFunctions . |
Modifier and Type | Class and Description |
---|---|
class |
ExtractTimestampsOperator<T>
Deprecated.
|
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 . |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.