Uses of Interface
org.apache.flink.runtime.state.KeyGroupedInternalPriorityQueue
-
Packages that use KeyGroupedInternalPriorityQueue Package Description 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 -
-
Uses of KeyGroupedInternalPriorityQueue in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return KeyGroupedInternalPriorityQueue Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>PriorityQueueSetFactory. create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)
Creates aKeyGroupedInternalPriorityQueue
.default <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>PriorityQueueSetFactory. create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
Creates aKeyGroupedInternalPriorityQueue
.<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>HeapPriorityQueuesManager. createOrUpdate(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>HeapPriorityQueuesManager. createOrUpdate(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
-
Uses of KeyGroupedInternalPriorityQueue in org.apache.flink.runtime.state.heap
Classes in org.apache.flink.runtime.state.heap that implement KeyGroupedInternalPriorityQueue Modifier and Type Class Description class
HeapPriorityQueueSet<T extends HeapPriorityQueueElement>
A heap-based priority queue with set semantics, based onHeapPriorityQueue
.class
KeyGroupPartitionedPriorityQueue<T,PQ extends InternalPriorityQueue<T> & HeapPriorityQueueElement>
This implementation ofInternalPriorityQueue
is internally partitioned into sub-queues per key-group and essentially works as a heap-of-heaps.Methods in org.apache.flink.runtime.state.heap that return KeyGroupedInternalPriorityQueue Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>HeapKeyedStateBackend. create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>HeapKeyedStateBackend. create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
-
Uses of KeyGroupedInternalPriorityQueue in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor that return KeyGroupedInternalPriorityQueue Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>AsyncKeyedStateBackendAdaptor. create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>AsyncKeyedStateBackendAdaptor. create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
-
Uses of KeyGroupedInternalPriorityQueue in org.apache.flink.streaming.api.operators
Fields in org.apache.flink.streaming.api.operators declared as KeyGroupedInternalPriorityQueue Modifier and Type Field 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.Methods in org.apache.flink.streaming.api.operators with parameters of type KeyGroupedInternalPriorityQueue Modifier and Type Method Description protected void
InternalTimerServiceAsyncImpl. foreachTimer(org.apache.flink.util.function.BiConsumerWithException<N,Long,Exception> consumer, KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K,N>> queue)
Iterator each timer in the queue, and invoke the consumer.protected void
InternalTimerServiceImpl. foreachTimer(org.apache.flink.util.function.BiConsumerWithException<N,Long,Exception> consumer, KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K,N>> queue)
-
Uses of KeyGroupedInternalPriorityQueue in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state that return KeyGroupedInternalPriorityQueue Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>BatchExecutionKeyedStateBackend. create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)
-