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.state.changelog |
Modifier and Type | Class and Description |
---|---|
class |
RocksDBCachingPriorityQueueSet<E extends HeapPriorityQueueElement>
A priority queue with set semantics, implemented on top of RocksDB.
|
Modifier and Type | Interface and Description |
---|---|
interface |
KeyGroupedInternalPriorityQueue<T>
This interface exists as (temporary) adapter between the new
InternalPriorityQueue and
the old way in which timers are written in a snapshot. |
Modifier and Type | Class and Description |
---|---|
class |
KeyGroupPartitionedPriorityQueue<T,PQ extends InternalPriorityQueue<T> & HeapPriorityQueueElement>
This implementation of
InternalPriorityQueue is internally partitioned into sub-queues
per key-group and essentially works as a heap-of-heaps. |
static interface |
KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T,PQS extends InternalPriorityQueue<T> & HeapPriorityQueueElement>
Factory that produces the sub-queues that represent the partitions of a
KeyGroupPartitionedPriorityQueue . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHeapPriorityQueue<T extends HeapPriorityQueueElement>
Abstract base class for heap (object array) based implementations of priority queues, with
support for fast deletes via
HeapPriorityQueueElement . |
class |
HeapPriorityQueue<T extends HeapPriorityQueueElement>
Basic heap-based priority queue for
HeapPriorityQueueElement objects. |
class |
HeapPriorityQueueSet<T extends HeapPriorityQueueElement>
A heap-based priority queue with set semantics, based on
HeapPriorityQueue . |
class |
KeyGroupPartitionedPriorityQueue<T,PQ extends InternalPriorityQueue<T> & HeapPriorityQueueElement>
This implementation of
InternalPriorityQueue is internally partitioned into sub-queues
per key-group and essentially works as a heap-of-heaps. |
Modifier and Type | Class and Description |
---|---|
class |
ChangelogKeyGroupedPriorityQueue<T>
A
KeyGroupedInternalPriorityQueue that keeps state on the underlying delegated KeyGroupedInternalPriorityQueue as well as on the state change log. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.