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 | |
org.apache.flink.state.changelog.restore | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.sorted.state |
Modifier and Type | Method and Description |
---|---|
<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) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
RocksDBKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer,
boolean allowFutureMetadataUpdates) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
RocksDBPriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer,
boolean allowFutureMetadataUpdates) |
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 |
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 | Method and Description |
---|---|
<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 | Class and Description |
---|---|
class |
ChangelogKeyGroupedPriorityQueue<T>
A
KeyGroupedInternalPriorityQueue that keeps state on the underlying delegated KeyGroupedInternalPriorityQueue as well as on the state change log. |
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> ChangelogKeyGroupedPriorityQueue<T> |
ChangelogStateFactory.create(String stateName,
KeyGroupedInternalPriorityQueue<T> internalPriorityQueue,
StateChangeLogger<T,Void> logger,
TypeSerializer<T> serializer) |
Constructor and Description |
---|
ChangelogKeyGroupedPriorityQueue(KeyGroupedInternalPriorityQueue<T> delegatedPriorityQueue,
StateChangeLogger<T,Void> logger,
TypeSerializer<T> serializer) |
Modifier and Type | Method and Description |
---|---|
<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. |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
ChangelogMigrationRestoreTarget.createPqState(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
Modifier and Type | Method and Description |
---|---|
<T> StateChangeApplier |
ChangelogApplierFactory.forPriorityQueue(KeyGroupedInternalPriorityQueue<T> priorityQueue,
TypeSerializer<T> serializer) |
Modifier and Type | Field and Description |
---|---|
protected KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K,N>> |
InternalTimerServiceImpl.eventTimeTimersQueue
Event time timers that are currently in-flight.
|
protected KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K,N>> |
InternalTimerServiceImpl.processingTimeTimersQueue
Processing time timers that are currently in-flight.
|
Modifier and Type | Method and Description |
---|---|
protected void |
InternalTimerServiceAsyncImpl.foreachTimer(BiConsumerWithException<N,Long,Exception> consumer,
KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K,N>> queue)
Iterator each timer in the queue, and invoke the consumer.
|
protected void |
InternalTimerServiceImpl.foreachTimer(BiConsumerWithException<N,Long,Exception> consumer,
KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K,N>> queue) |
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.