Package | Description |
---|---|
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations
on data streams.
|
Class and Description |
---|
AbstractAlignedProcessingTimeWindowOperator |
AbstractKeyedTimePanes
Base class for a multiple key/value maps organized in panes.
|
AccumulatingKeyedTimePanes |
AggregatingKeyedTimePanes |
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.
|
NonKeyedWindowOperator
Window operator for non-keyed windows.
|
NonKeyedWindowOperator.Context
The
Context is responsible for keeping track of the state of one pane. |
WindowOperator
An operator that implements the logic for windowing based on a
WindowAssigner and
Trigger . |
WindowOperator.Context
Context is a utility for handling Trigger invocations. |
WindowOperator.Timer
Internal class for keeping track of in-flight timers.
|
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.