Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.heap |
This package contains the classes for key/value state backends that store the state on the JVM
heap as objects.
|
org.apache.flink.streaming.api.operators |
Class and Description |
---|
HeapPriorityQueueElement
Interface for objects that can be managed by a
HeapPriorityQueue . |
InternalKeyContext
This interface is the current context of a keyed state.
|
Class and Description |
---|
HeapPriorityQueueElement
Interface for objects that can be managed by a
HeapPriorityQueue . |
InternalKeyContext
This interface is the current context of a keyed state.
|
Class and Description |
---|
AbstractHeapPriorityQueue
Abstract base class for heap (object array) based implementations of priority queues, with
support for fast deletes via
HeapPriorityQueueElement . |
CopyOnWriteSkipListStateMapSnapshot
This class represents the snapshot of a
CopyOnWriteSkipListStateMap . |
CopyOnWriteStateMap
Implementation of Flink's in-memory state maps with copy-on-write support.
|
CopyOnWriteStateMapSnapshot
This class represents the snapshot of a
CopyOnWriteStateMap . |
CopyOnWriteStateTableSnapshot
This class represents the snapshot of a
CopyOnWriteStateTable and has a role in operator
state checkpointing. |
HeapKeyedStateBackend
A
AbstractKeyedStateBackend that keeps state on the Java Heap and will serialize state to
streams provided by a CheckpointStreamFactory upon checkpointing. |
HeapPriorityQueue
Basic heap-based priority queue for
HeapPriorityQueueElement objects. |
HeapPriorityQueueElement
Interface for objects that can be managed by a
HeapPriorityQueue . |
HeapPriorityQueueSet
A heap-based priority queue with set semantics, based on
HeapPriorityQueue . |
HeapPriorityQueueSetFactory
Factory for
HeapPriorityQueueSet . |
HeapPriorityQueueSnapshotRestoreWrapper
This wrapper combines a HeapPriorityQueue with backend meta data.
|
InternalKeyContext
This interface is the current context of a keyed state.
|
KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory
Factory that produces the sub-queues that represent the partitions of a
KeyGroupPartitionedPriorityQueue . |
LevelIndexHeader
Head level index for skip list.
|
NestedStateMap |
NodeStatus
Status of the node.
|
StateMap
Base class for state maps.
|
StateMapSnapshot
Base class for snapshots of a
StateMap . |
StateTable
Base class for state tables.
|
Class and Description |
---|
HeapPriorityQueueElement
Interface for objects that can be managed by a
HeapPriorityQueue . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.