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 |
---|---|
void |
GlobalWindows.NeverTrigger.onMerge(GlobalWindow window,
Trigger.OnMergeContext ctx) |
void |
GlobalWindows.EndOfStreamTrigger.onMerge(GlobalWindow window,
Trigger.OnMergeContext ctx) |
Modifier and Type | Method and Description |
---|---|
void |
ProcessingTimeTrigger.onMerge(TimeWindow window,
Trigger.OnMergeContext ctx) |
void |
EventTimeTrigger.onMerge(TimeWindow window,
Trigger.OnMergeContext ctx) |
void |
ContinuousProcessingTimeTrigger.onMerge(W window,
Trigger.OnMergeContext ctx) |
void |
Trigger.onMerge(W window,
Trigger.OnMergeContext ctx)
Called when several windows have been merged into one window by the
WindowAssigner . |
void |
PurgingTrigger.onMerge(W window,
Trigger.OnMergeContext ctx) |
void |
CountTrigger.onMerge(W window,
Trigger.OnMergeContext ctx) |
void |
ContinuousEventTimeTrigger.onMerge(W window,
Trigger.OnMergeContext ctx) |
Modifier and Type | Class and Description |
---|---|
class |
WindowOperator.Context
Context is a utility for handling Trigger invocations. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.