Package | Description |
---|---|
org.apache.flink.streaming.api.windowing.assigners | |
org.apache.flink.streaming.api.windowing.triggers | |
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 |
---|---|
TriggerResult |
GlobalWindows.NeverTrigger.onElement(Object element,
long timestamp,
GlobalWindow window,
Trigger.TriggerContext ctx) |
TriggerResult |
GlobalWindows.NeverTrigger.onEventTime(long time,
GlobalWindow window,
Trigger.TriggerContext ctx) |
TriggerResult |
GlobalWindows.NeverTrigger.onProcessingTime(long time,
GlobalWindow window,
Trigger.TriggerContext ctx) |
Modifier and Type | Method and Description |
---|---|
TriggerResult |
EventTimeTrigger.onElement(Object element,
long timestamp,
TimeWindow window,
Trigger.TriggerContext ctx) |
TriggerResult |
ProcessingTimeTrigger.onElement(Object element,
long timestamp,
TimeWindow window,
Trigger.TriggerContext ctx) |
TriggerResult |
CountTrigger.onElement(Object element,
long timestamp,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
ContinuousEventTimeTrigger.onElement(Object element,
long timestamp,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
ContinuousProcessingTimeTrigger.onElement(Object element,
long timestamp,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
DeltaTrigger.onElement(T element,
long timestamp,
W window,
Trigger.TriggerContext ctx) |
abstract TriggerResult |
Trigger.onElement(T element,
long timestamp,
W window,
Trigger.TriggerContext ctx)
Called for every element that gets added to a pane.
|
TriggerResult |
PurgingTrigger.onElement(T element,
long timestamp,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
EventTimeTrigger.onEventTime(long time,
TimeWindow window,
Trigger.TriggerContext ctx) |
TriggerResult |
ProcessingTimeTrigger.onEventTime(long time,
TimeWindow window,
Trigger.TriggerContext ctx) |
TriggerResult |
CountTrigger.onEventTime(long time,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
DeltaTrigger.onEventTime(long time,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
ContinuousEventTimeTrigger.onEventTime(long time,
W window,
Trigger.TriggerContext ctx) |
abstract TriggerResult |
Trigger.onEventTime(long time,
W window,
Trigger.TriggerContext ctx)
Called when an event-time timer that was set using the trigger context fires.
|
TriggerResult |
PurgingTrigger.onEventTime(long time,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
ContinuousProcessingTimeTrigger.onEventTime(long time,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
EventTimeTrigger.onProcessingTime(long time,
TimeWindow window,
Trigger.TriggerContext ctx) |
TriggerResult |
ProcessingTimeTrigger.onProcessingTime(long time,
TimeWindow window,
Trigger.TriggerContext ctx) |
TriggerResult |
CountTrigger.onProcessingTime(long time,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
DeltaTrigger.onProcessingTime(long time,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
ContinuousEventTimeTrigger.onProcessingTime(long time,
W window,
Trigger.TriggerContext ctx) |
abstract TriggerResult |
Trigger.onProcessingTime(long time,
W window,
Trigger.TriggerContext ctx)
Called when a processing-time timer that was set using the trigger context fires.
|
TriggerResult |
PurgingTrigger.onProcessingTime(long time,
W window,
Trigger.TriggerContext ctx) |
TriggerResult |
ContinuousProcessingTimeTrigger.onProcessingTime(long time,
W window,
Trigger.TriggerContext ctx) |
static TriggerResult |
TriggerResult.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static TriggerResult[] |
TriggerResult.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
TriggerResult |
WindowOperator.Context.onElement(StreamRecord<IN> element) |
TriggerResult |
WindowOperator.Context.onEventTime(long time) |
TriggerResult |
WindowOperator.Context.onProcessingTime(long time) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.