Package 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.
-
Interface Summary Interface Description HeapPriorityQueueElement Interface for objects that can be managed by aHeapPriorityQueue.KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T,PQS extends InternalPriorityQueue<T> & HeapPriorityQueueElement> Factory that produces the sub-queues that represent the partitions of aKeyGroupPartitionedPriorityQueue. -
Class Summary Class Description AbstractHeapPriorityQueue<T extends HeapPriorityQueueElement> Abstract base class for heap (object array) based implementations of priority queues, with support for fast deletes viaHeapPriorityQueueElement.AbstractHeapPriorityQueueElement Abstract base class forHeapPriorityQueueElement.AbstractHeapState<K,N,SV> Base class for partitionedStateimplementations that are backed by a regular heap hash map.CopyOnWriteStateMap<K,N,S> Implementation of Flink's in-memory state maps with copy-on-write support.CopyOnWriteStateMap.StateMapEntry<K,N,S> One entry in theCopyOnWriteStateMap.CopyOnWriteStateMapSnapshot<K,N,S> This class represents the snapshot of aCopyOnWriteStateMap.CopyOnWriteStateTable<K,N,S> This implementation ofStateTableusesCopyOnWriteStateMap.CopyOnWriteStateTableSnapshot<K,N,S> This class represents the snapshot of aCopyOnWriteStateTableand has a role in operator state checkpointing.HeapKeyedStateBackend<K> AAbstractKeyedStateBackendthat keeps state on the Java Heap and will serialize state to streams provided by aCheckpointStreamFactoryupon checkpointing.HeapKeyedStateBackendBuilder<K> Builder class forHeapKeyedStateBackendwhich handles all necessary initializations and clean ups.HeapKeyValueStateIterator AKeyValueStateIteratorover Heap backend snapshot resources.HeapPriorityQueue<T extends HeapPriorityQueueElement> Basic heap-based priority queue forHeapPriorityQueueElementobjects.HeapPriorityQueueSet<T extends HeapPriorityQueueElement> A heap-based priority queue with set semantics, based onHeapPriorityQueue.HeapPriorityQueueSetFactory Factory forHeapPriorityQueueSet.HeapPriorityQueueSnapshotRestoreWrapper<T extends HeapPriorityQueueElement> This wrapper combines a HeapPriorityQueue with backend meta data.HeapPriorityQueueStateSnapshot<T> This class represents the snapshot of anHeapPriorityQueueSet.HeapRestoreOperation<K> Implementation of heap restore operation.HeapSavepointRestoreOperation<K> Implementation of heap savepoint restore operation.KeyGroupPartitionedPriorityQueue<T,PQ extends InternalPriorityQueue<T> & HeapPriorityQueueElement> This implementation ofInternalPriorityQueueis internally partitioned into sub-queues per key-group and essentially works as a heap-of-heaps.StateMap<K,N,S> Base class for state maps.StateMapSnapshot<K,N,S,T extends StateMap<K,N,S>> Base class for snapshots of aStateMap.StateTable<K,N,S> Base class for state tables.StateTableByKeyGroupReaders This class provides a static factory method to create different implementations ofStateSnapshotKeyGroupReaderdepending on the provided serialization format version.