Package | Description |
---|---|
org.apache.flink.streaming.api.windowing.evictors | |
org.apache.flink.streaming.connectors.kinesis.util | |
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations on data streams.
|
Class and Description |
---|
TimestampedValue
Stores the value and the timestamp of the record.
|
Class and Description |
---|
TimestampedValue
Stores the value and the timestamp of the record.
|
Class and Description |
---|
KeyMap
A special Hash Map implementation that can be traversed efficiently in sync with other hash maps.
|
KeyMap.Entry
An entry in the hash table.
|
KeyMap.LazyFactory
A factory for lazy/on-demand instantiation of values.
|
KeyMap.TraversalEvaluator
A visitor for a traversal over the union of multiple hash maps.
|
MergingWindowSet
Utility for keeping track of merging
Windows when using a MergingWindowAssigner in a WindowOperator . |
MergingWindowSet.MergeFunction
Callback for
MergingWindowSet.addWindow(Window, MergeFunction) . |
TimestampedValue
Stores the value and the timestamp of the record.
|
WindowOperator
An operator that implements the logic for windowing based on a
WindowAssigner and Trigger . |
WindowOperator.AbstractPerWindowStateStore
Base class for per-window
KeyedStateStores . |
WindowOperator.Context
Context is a utility for handling Trigger invocations. |
WindowOperator.Timer
Internal class for keeping track of in-flight timers.
|
WindowOperator.WindowContext
A utility class for handling
ProcessWindowFunction invocations. |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.