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 |
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 | Class and Description |
---|---|
class |
RocksDBCachingPriorityQueueSet<E extends HeapPriorityQueueElement>
A priority queue with set semantics, implemented on top of RocksDB.
|
Modifier and Type | Method and Description |
---|---|
<T extends HeapPriorityQueueElement & PriorityComparable & Keyed> |
RocksDBPriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable & Keyed> |
RocksDBKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
Modifier and Type | Method and Description |
---|---|
<T extends HeapPriorityQueueElement & PriorityComparable & Keyed> |
PriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer)
Creates a
KeyGroupedInternalPriorityQueue . |
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 |
HeapPriorityQueueSnapshotRestoreWrapper<T extends HeapPriorityQueueElement>
This wrapper combines a HeapPriorityQueue with backend meta data.
|
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 | Field and Description |
---|---|
protected T[] |
AbstractHeapPriorityQueue.queue
The array that represents the heap-organized priority queue.
|
Modifier and Type | Method and Description |
---|---|
<T extends HeapPriorityQueueElement & PriorityComparable & Keyed> |
HeapPriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable & Keyed> |
HeapKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
Modifier and Type | Class and Description |
---|---|
class |
TimerHeapInternalTimer<K,N>
Implementation of
InternalTimer to use with a HeapPriorityQueueSet . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.