Uses of Package
org.apache.flink.streaming.api.windowing.assigners
-
Classes in org.apache.flink.streaming.api.windowing.assigners used by org.apache.flink.runtime.asyncprocessing.operators.windowing Class Description WindowAssigner AWindowAssigner
assigns zero or moreWindows
to an element.WindowAssigner.WindowAssignerContext A context provided to theWindowAssigner
that allows it to query the current processing time. -
Classes in org.apache.flink.streaming.api.windowing.assigners used by org.apache.flink.streaming.api.datastream Class Description WindowAssigner AWindowAssigner
assigns zero or moreWindows
to an element. -
Classes in org.apache.flink.streaming.api.windowing.assigners used by org.apache.flink.streaming.api.windowing.assigners Class Description GlobalWindows AWindowAssigner
that assigns all elements to the sameGlobalWindow
.MergingWindowAssigner.MergeCallback Callback to be used inMergingWindowAssigner.mergeWindows(Collection, MergeCallback)
for specifying which windows should be merged.SlidingEventTimeWindows AWindowAssigner
that windows elements into sliding windows based on the timestamp of the elements.SlidingProcessingTimeWindows AWindowAssigner
that windows elements into sliding windows based on the current system time of the machine the operation is running on.TumblingEventTimeWindows AWindowAssigner
that windows elements into windows based on the timestamp of the elements.TumblingProcessingTimeWindows AWindowAssigner
that windows elements into windows based on the current system time of the machine the operation is running on.WindowAssigner AWindowAssigner
assigns zero or moreWindows
to an element.WindowAssigner.WindowAssignerContext A context provided to theWindowAssigner
that allows it to query the current processing time.WindowStagger AWindowStagger
staggers offset in runtime for each window assignment. -
Classes in org.apache.flink.streaming.api.windowing.assigners used by org.apache.flink.streaming.api.windowing.windows Class Description MergingWindowAssigner.MergeCallback Callback to be used inMergingWindowAssigner.mergeWindows(Collection, MergeCallback)
for specifying which windows should be merged. -
Classes in org.apache.flink.streaming.api.windowing.assigners used by org.apache.flink.streaming.runtime.operators.windowing Class Description MergingWindowAssigner AWindowAssigner
that can merge windows.WindowAssigner AWindowAssigner
assigns zero or moreWindows
to an element.WindowAssigner.WindowAssignerContext A context provided to theWindowAssigner
that allows it to query the current processing time.