Class MergingWindowAssigner<T,W extends Window>
- java.lang.Object
-
- org.apache.flink.streaming.api.windowing.assigners.WindowAssigner<T,W>
-
- org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner<T,W>
-
- Type Parameters:
T
- The type of elements that this WindowAssigner can assign windows to.W
- The type ofWindow
that this assigner assigns.
- All Implemented Interfaces:
Serializable
@PublicEvolving public abstract class MergingWindowAssigner<T,W extends Window> extends WindowAssigner<T,W>
AWindowAssigner
that can merge windows.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static interface
MergingWindowAssigner.MergeCallback<W>
Callback to be used inmergeWindows(Collection, MergeCallback)
for specifying which windows should be merged.-
Nested classes/interfaces inherited from class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
WindowAssigner.WindowAssignerContext
-
-
Constructor Summary
Constructors Constructor Description MergingWindowAssigner()
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description abstract void
mergeWindows(Collection<W> windows, MergingWindowAssigner.MergeCallback<W> callback)
Determines which windows (if any) should be merged.-
Methods inherited from class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
assignWindows, getDefaultTrigger, getWindowSerializer, isEventTime
-
-
-
-
Method Detail
-
mergeWindows
public abstract void mergeWindows(Collection<W> windows, MergingWindowAssigner.MergeCallback<W> callback)
Determines which windows (if any) should be merged.- Parameters:
windows
- The window candidates.callback
- A callback that can be invoked to signal which windows should be merged.
-
-