Package | Description |
---|---|
org.apache.flink.state.api | |
org.apache.flink.streaming.api.datastream | |
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 |
---|---|
WindowedStateTransformation<T,K,W> |
WindowedStateTransformation.trigger(Trigger<? super T,? super W> trigger)
Sets the
Trigger that should be used to trigger window emission. |
WindowedOperatorTransformation<T,K,W> |
WindowedOperatorTransformation.trigger(Trigger<? super T,? super W> trigger)
Sets the
Trigger that should be used to trigger window emission. |
Modifier and Type | Method and Description |
---|---|
CoGroupedStreams.WithWindow<T1,T2,KEY,W> |
CoGroupedStreams.WithWindow.trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newTrigger)
Sets the
Trigger that should be used to trigger window emission. |
JoinedStreams.WithWindow<T1,T2,KEY,W> |
JoinedStreams.WithWindow.trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> newTrigger)
Sets the
Trigger that should be used to trigger window emission. |
WindowedStream<T,K,W> |
WindowedStream.trigger(Trigger<? super T,? super W> trigger)
Sets the
Trigger that should be used to trigger window emission. |
AllWindowedStream<T,W> |
AllWindowedStream.trigger(Trigger<? super T,? super W> trigger)
Sets the
Trigger that should be used to trigger window emission. |
Constructor and Description |
---|
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor,
Time allowedLateness) |
WithWindow(DataStream<T1> input1,
DataStream<T2> input2,
KeySelector<T1,KEY> keySelector1,
KeySelector<T2,KEY> keySelector2,
TypeInformation<KEY> keyType,
WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor,
Time allowedLateness) |
Modifier and Type | Class and Description |
---|---|
static class |
GlobalWindows.NeverTrigger
A trigger that never fires, as default Trigger for GlobalWindows.
|
Modifier and Type | Class and Description |
---|---|
class |
ContinuousEventTimeTrigger<W extends Window>
A
Trigger that continuously fires based on a given time interval. |
class |
ContinuousProcessingTimeTrigger<W extends Window>
A
Trigger that continuously fires based on a given time interval as measured by the clock
of the machine on which the job is running. |
class |
CountTrigger<W extends Window>
A
Trigger that fires once the count of elements in a pane reaches the given count. |
class |
DeltaTrigger<T,W extends Window>
A
Trigger that fires based on a DeltaFunction and a threshold. |
class |
EventTimeTrigger
A
Trigger that fires once the watermark passes the end of the window to which a pane
belongs. |
class |
ProcessingTimeoutTrigger<T,W extends Window>
|
class |
ProcessingTimeTrigger
A
Trigger that fires once the current system time passes the end of the window to which a
pane belongs. |
class |
PurgingTrigger<T,W extends Window>
A trigger that can turn any
Trigger into a purging Trigger . |
Modifier and Type | Method and Description |
---|---|
Trigger<T,W> |
PurgingTrigger.getNestedTrigger() |
Modifier and Type | Method and Description |
---|---|
static <T,W extends Window> |
PurgingTrigger.of(Trigger<T,W> nestedTrigger)
Creates a new purging trigger from the given
Trigger . |
static <T,W extends Window> |
ProcessingTimeoutTrigger.of(Trigger<T,W> nestedTrigger,
java.time.Duration timeout)
Creates a new
ProcessingTimeoutTrigger that fires when the inner trigger is fired or
when the timeout timer fires. |
static <T,W extends Window> |
ProcessingTimeoutTrigger.of(Trigger<T,W> nestedTrigger,
java.time.Duration timeout,
boolean resetTimerOnNewRecord,
boolean shouldClearOnTimeout)
Creates a new
ProcessingTimeoutTrigger that fires when the inner trigger is fired or
when the timeout timer fires. |
Modifier and Type | Method and Description |
---|---|
Trigger<? super IN,? super W> |
WindowOperator.getTrigger() |
Modifier and Type | Method and Description |
---|---|
void |
WindowOperatorBuilder.trigger(Trigger<? super T,? super W> trigger) |
Constructor and Description |
---|
EvictingWindowOperator(WindowAssigner<? super IN,W> windowAssigner,
TypeSerializer<W> windowSerializer,
KeySelector<IN,K> keySelector,
TypeSerializer<K> keySerializer,
StateDescriptor<? extends ListState<StreamRecord<IN>>,?> windowStateDescriptor,
InternalWindowFunction<Iterable<IN>,OUT,K,W> windowFunction,
Trigger<? super IN,? super W> trigger,
Evictor<? super IN,? super W> evictor,
long allowedLateness,
OutputTag<IN> lateDataOutputTag) |
WindowOperator(WindowAssigner<? super IN,W> windowAssigner,
TypeSerializer<W> windowSerializer,
KeySelector<IN,K> keySelector,
TypeSerializer<K> keySerializer,
StateDescriptor<? extends AppendingState<IN,ACC>,?> windowStateDescriptor,
InternalWindowFunction<ACC,OUT,K,W> windowFunction,
Trigger<? super IN,? super W> trigger,
long allowedLateness,
OutputTag<IN> lateDataOutputTag)
Creates a new
WindowOperator based on the given policies and user functions. |
WindowOperatorBuilder(WindowAssigner<? super T,W> windowAssigner,
Trigger<? super T,? super W> trigger,
ExecutionConfig config,
TypeInformation<T> inputType,
KeySelector<T,K> keySelector,
TypeInformation<K> keyType) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.