Uses of Package
org.apache.flink.runtime.state.heap
-
Packages that use org.apache.flink.runtime.state.heap Package Description org.apache.flink.runtime.source.coordinator 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.runtime.state.v2.adaptor org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state -
Classes in org.apache.flink.runtime.state.heap used by org.apache.flink.runtime.source.coordinator Class Description AbstractHeapPriorityQueueElement Abstract base class forHeapPriorityQueueElement
.HeapPriorityQueueElement Interface for objects that can be managed by aHeapPriorityQueue
. -
Classes in org.apache.flink.runtime.state.heap used by org.apache.flink.runtime.state Class Description HeapPriorityQueueElement Interface for objects that can be managed by aHeapPriorityQueue
.HeapPriorityQueueSetFactory Factory forHeapPriorityQueueSet
.HeapPriorityQueueSnapshotRestoreWrapper This wrapper combines a HeapPriorityQueue with backend meta data. -
Classes in org.apache.flink.runtime.state.heap used by org.apache.flink.runtime.state.heap Class Description AbstractHeapPriorityQueue Abstract base class for heap (object array) based implementations of priority queues, with support for fast deletes viaHeapPriorityQueueElement
.AbstractHeapState Base class for partitionedState
implementations that are backed by a regular heap hash map.CopyOnWriteStateMap Implementation of Flink's in-memory state maps with copy-on-write support.CopyOnWriteStateMapSnapshot This class represents the snapshot of aCopyOnWriteStateMap
.CopyOnWriteStateTableSnapshot This class represents the snapshot of aCopyOnWriteStateTable
and has a role in operator state checkpointing.HeapKeyedStateBackend AAbstractKeyedStateBackend
that keeps state on the Java Heap and will serialize state to streams provided by aCheckpointStreamFactory
upon checkpointing.HeapPriorityQueue Basic heap-based priority queue forHeapPriorityQueueElement
objects.HeapPriorityQueueElement Interface for objects that can be managed by aHeapPriorityQueue
.HeapPriorityQueueSet A heap-based priority queue with set semantics, based onHeapPriorityQueue
.HeapPriorityQueueSetFactory Factory forHeapPriorityQueueSet
.HeapPriorityQueueSnapshotRestoreWrapper This wrapper combines a HeapPriorityQueue with backend meta data.HeapPriorityQueueStateSnapshot This class represents the snapshot of anHeapPriorityQueueSet
.KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory Factory that produces the sub-queues that represent the partitions of aKeyGroupPartitionedPriorityQueue
.StateMap Base class for state maps.StateMapSnapshot Base class for snapshots of aStateMap
.StateTable Base class for state tables. -
Classes in org.apache.flink.runtime.state.heap used by org.apache.flink.runtime.state.v2.adaptor Class Description HeapPriorityQueueElement Interface for objects that can be managed by aHeapPriorityQueue
. -
Classes in org.apache.flink.runtime.state.heap used by org.apache.flink.streaming.api.operators Class Description HeapPriorityQueueElement Interface for objects that can be managed by aHeapPriorityQueue
. -
Classes in org.apache.flink.runtime.state.heap used by org.apache.flink.streaming.api.operators.sorted.state Class Description HeapPriorityQueueElement Interface for objects that can be managed by aHeapPriorityQueue
.