Package | Description |
---|---|
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.api.windowing.assigners | |
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations
on data streams.
|
Modifier and Type | Method and Description |
---|---|
<W extends Window> |
CoGroupedStreams.Where.EqualTo.window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> assigner)
Specifies the window on which the co-group operation works.
|
<W extends Window> |
JoinedStreams.Where.EqualTo.window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> assigner)
Specifies the window on which the join operation works.
|
<W extends Window> |
KeyedStream.window(WindowAssigner<? super T,W> assigner)
Windows this data stream to a
WindowedStream , which evaluates windows
over a key grouped stream. |
<W extends Window> |
DataStream.windowAll(WindowAssigner<? super T,W> assigner)
Windows this data stream to a
KeyedTriggerWindowDataStream , which evaluates windows
over a key grouped stream. |
Modifier and Type | Class and Description |
---|---|
class |
BaseAlignedWindowAssigner
Deprecated.
will be removed in a future version. please use other
WindowAssigner s listed under
org.apache.flink.streaming.api.windowing.assigners . |
class |
DynamicEventTimeSessionWindows<T>
A
WindowAssigner that windows elements into sessions based on the timestamp of the
elements. |
class |
DynamicProcessingTimeSessionWindows<T>
A
WindowAssigner that windows elements into sessions based on the current processing
time. |
class |
EventTimeSessionWindows
A
WindowAssigner that windows elements into sessions based on the timestamp of the
elements. |
class |
GlobalWindows
A
WindowAssigner that assigns all elements to the same GlobalWindow . |
class |
MergingWindowAssigner<T,W extends Window>
A
WindowAssigner that can merge windows. |
class |
ProcessingTimeSessionWindows
A
WindowAssigner that windows elements into sessions based on the current processing
time. |
class |
SlidingEventTimeWindows
A
WindowAssigner that windows elements into sliding windows based on the timestamp of the
elements. |
class |
SlidingProcessingTimeWindows
A
WindowAssigner that windows elements into sliding windows based on the current
system time of the machine the operation is running on. |
class |
SlidingTimeWindows
Deprecated.
Please use
SlidingEventTimeWindows . |
class |
TumblingEventTimeWindows
A
WindowAssigner that windows elements into windows based on the timestamp of the
elements. |
class |
TumblingProcessingTimeWindows
A
WindowAssigner that windows elements into windows based on the current
system time of the machine the operation is running on. |
class |
TumblingTimeWindows
Deprecated.
Please use
TumblingEventTimeWindows . |
Modifier and Type | Field and Description |
---|---|
protected WindowAssigner<? super IN,W> |
WindowOperator.windowAssigner |
Modifier and Type | Method and Description |
---|---|
WindowAssigner<? super IN,W> |
WindowOperator.getWindowAssigner() |
Constructor and Description |
---|
EvictingWindowOperator(WindowAssigner<? super IN,W> windowAssigner,
TypeSerializer<W> windowSerializer,
KeySelector<IN,K> keySelector,
TypeSerializer<K> keySerializer,
StateDescriptor<? extends ListState<StreamRecord<IN>>,?> windowStateDescriptor,
InternalWindowFunction<Iterable<IN>,OUT,K,W> windowFunction,
Trigger<? super IN,? super W> trigger,
Evictor<? super IN,? super W> evictor,
long allowedLateness,
OutputTag<IN> lateDataOutputTag) |
WindowOperator(WindowAssigner<? super IN,W> windowAssigner,
TypeSerializer<W> windowSerializer,
KeySelector<IN,K> keySelector,
TypeSerializer<K> keySerializer,
StateDescriptor<? extends AppendingState<IN,ACC>,?> windowStateDescriptor,
InternalWindowFunction<ACC,OUT,K,W> windowFunction,
Trigger<? super IN,? super W> trigger,
long allowedLateness,
OutputTag<IN> lateDataOutputTag)
Creates a new
WindowOperator based on the given policies and user functions. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.