Class GlobalWindows.NeverTrigger
- java.lang.Object
-
- org.apache.flink.streaming.api.windowing.triggers.Trigger<Object,GlobalWindow>
-
- org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
-
- All Implemented Interfaces:
Serializable
- Enclosing class:
- GlobalWindows
@Internal public static class GlobalWindows.NeverTrigger extends Trigger<Object,GlobalWindow>
A trigger that never fires, as default Trigger for GlobalWindows.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.streaming.api.windowing.triggers.Trigger
Trigger.OnMergeContext, Trigger.TriggerContext
-
-
Constructor Summary
Constructors Constructor Description NeverTrigger()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
clear(GlobalWindow window, Trigger.TriggerContext ctx)
Clears any state that the trigger might still hold for the given window.TriggerResult
onElement(Object element, long timestamp, GlobalWindow window, Trigger.TriggerContext ctx)
Called for every element that gets added to a pane.TriggerResult
onEventTime(long time, GlobalWindow window, Trigger.TriggerContext ctx)
Called when an event-time timer that was set using the trigger context fires.void
onMerge(GlobalWindow window, Trigger.OnMergeContext ctx)
Called when several windows have been merged into one window by theWindowAssigner
.TriggerResult
onProcessingTime(long time, GlobalWindow window, Trigger.TriggerContext ctx)
Called when a processing-time timer that was set using the trigger context fires.
-
-
-
Method Detail
-
onElement
public TriggerResult onElement(Object element, long timestamp, GlobalWindow window, Trigger.TriggerContext ctx)
Description copied from class:Trigger
Called for every element that gets added to a pane. The result of this will determine whether the pane is evaluated to emit results.- Specified by:
onElement
in classTrigger<Object,GlobalWindow>
- Parameters:
element
- The element that arrived.timestamp
- The timestamp of the element that arrived.window
- The window to which the element is being added.ctx
- A context object that can be used to register timer callbacks.
-
onEventTime
public TriggerResult onEventTime(long time, GlobalWindow window, Trigger.TriggerContext ctx)
Description copied from class:Trigger
Called when an event-time timer that was set using the trigger context fires.- Specified by:
onEventTime
in classTrigger<Object,GlobalWindow>
- Parameters:
time
- The timestamp at which the timer fired.window
- The window for which the timer fired.ctx
- A context object that can be used to register timer callbacks.
-
onProcessingTime
public TriggerResult onProcessingTime(long time, GlobalWindow window, Trigger.TriggerContext ctx)
Description copied from class:Trigger
Called when a processing-time timer that was set using the trigger context fires.- Specified by:
onProcessingTime
in classTrigger<Object,GlobalWindow>
- Parameters:
time
- The timestamp at which the timer fired.window
- The window for which the timer fired.ctx
- A context object that can be used to register timer callbacks.
-
clear
public void clear(GlobalWindow window, Trigger.TriggerContext ctx) throws Exception
Description copied from class:Trigger
Clears any state that the trigger might still hold for the given window. This is called when a window is purged. Timers set usingTrigger.TriggerContext.registerEventTimeTimer(long)
andTrigger.TriggerContext.registerProcessingTimeTimer(long)
should be deleted here as well as state acquired usingTrigger.TriggerContext.getPartitionedState(StateDescriptor)
.- Specified by:
clear
in classTrigger<Object,GlobalWindow>
- Throws:
Exception
-
onMerge
public void onMerge(GlobalWindow window, Trigger.OnMergeContext ctx)
Description copied from class:Trigger
Called when several windows have been merged into one window by theWindowAssigner
.- Overrides:
onMerge
in classTrigger<Object,GlobalWindow>
- Parameters:
window
- The new window that results from the merge.ctx
- A context object that can be used to register timer callbacks and access state.
-
-