Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
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.state.changelog | |
org.apache.flink.state.changelog.restore | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.sorted.state |
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<? super T> & Keyed<?>> |
RocksDBPriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
RocksDBKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
RocksDBPriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer,
boolean allowFutureMetadataUpdates) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
RocksDBKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer,
boolean allowFutureMetadataUpdates) |
Modifier and Type | Class and Description |
---|---|
static class |
SourceCoordinator.WatermarkElement
The watermark element for
HeapPriorityQueue . |
Modifier and Type | Method and Description |
---|---|
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
PriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer)
Creates a
KeyGroupedInternalPriorityQueue . |
default <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
PriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer,
boolean allowFutureMetadataUpdates)
Creates a
KeyGroupedInternalPriorityQueue . |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
HeapPriorityQueuesManager.createOrUpdate(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
HeapPriorityQueuesManager.createOrUpdate(String stateName,
TypeSerializer<T> byteOrderedElementSerializer,
boolean allowFutureMetadataUpdates) |
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 | Class and Description |
---|---|
class |
AbstractHeapPriorityQueueElement
Abstract base class for
HeapPriorityQueueElement . |
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<? super T> & Keyed<?>> |
HeapPriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
HeapKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
HeapKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer,
boolean allowFutureMetadataUpdates) |
Modifier and Type | Method and Description |
---|---|
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
ChangelogKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
Modifier and Type | Method and Description |
---|---|
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
ChangelogMigrationRestoreTarget.createPqState(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
ChangelogRestoreTarget.createPqState(String stateName,
TypeSerializer<T> byteOrderedElementSerializer)
Creates a
KeyGroupedInternalPriorityQueue which could be retrieved by #getExistingState(String, BackendStateType) in the restore procedure. |
Modifier and Type | Class and Description |
---|---|
class |
TimerHeapInternalTimer<K,N>
Implementation of
InternalTimer to use with a HeapPriorityQueueSet . |
Modifier and Type | Method and Description |
---|---|
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
BatchExecutionKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.