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 AWindowAssignerassigns zero or moreWindowsto an element.WindowAssigner.WindowAssignerContext A context provided to theWindowAssignerthat 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 AWindowAssignerassigns zero or moreWindowsto an element. -
Classes in org.apache.flink.streaming.api.windowing.assigners used by org.apache.flink.streaming.api.windowing.assigners Class Description GlobalWindows AWindowAssignerthat assigns all elements to the sameGlobalWindow.MergingWindowAssigner.MergeCallback Callback to be used inMergingWindowAssigner.mergeWindows(Collection, MergeCallback)for specifying which windows should be merged.SlidingEventTimeWindows AWindowAssignerthat windows elements into sliding windows based on the timestamp of the elements.SlidingProcessingTimeWindows AWindowAssignerthat windows elements into sliding windows based on the current system time of the machine the operation is running on.TumblingEventTimeWindows AWindowAssignerthat windows elements into windows based on the timestamp of the elements.TumblingProcessingTimeWindows AWindowAssignerthat windows elements into windows based on the current system time of the machine the operation is running on.WindowAssigner AWindowAssignerassigns zero or moreWindowsto an element.WindowAssigner.WindowAssignerContext A context provided to theWindowAssignerthat allows it to query the current processing time.WindowStagger AWindowStaggerstaggers 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 AWindowAssignerthat can merge windows.WindowAssigner AWindowAssignerassigns zero or moreWindowsto an element.WindowAssigner.WindowAssignerContext A context provided to theWindowAssignerthat allows it to query the current processing time.