Package org.apache.flink.runtime.state
Interface PriorityQueueSetFactory
-
- All Known Subinterfaces:
AsyncKeyedStateBackend<K>,CheckpointableKeyedStateBackend<K>,KeyedStateBackend<K>,TestableKeyedStateBackend<K>
- All Known Implementing Classes:
AbstractKeyedStateBackend,AsyncKeyedStateBackendAdaptor,BatchExecutionKeyedStateBackend,HeapKeyedStateBackend,HeapPriorityQueueSetFactory
public interface PriorityQueueSetFactoryFactory forKeyGroupedInternalPriorityQueueinstances.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)Creates aKeyGroupedInternalPriorityQueue.default <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>create(String stateName, org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)Creates aKeyGroupedInternalPriorityQueue.
-
-
-
Method Detail
-
create
@Nonnull <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> KeyGroupedInternalPriorityQueue<T> create(@Nonnull String stateName, @Nonnull org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer)
Creates aKeyGroupedInternalPriorityQueue.- Type Parameters:
T- type of the stored elements.- Parameters:
stateName- unique name for associated with this queue.byteOrderedElementSerializer- a serializer that with a format that is lexicographically ordered in alignment with elementPriorityComparator.- Returns:
- the queue with the specified unique name.
-
create
default <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> KeyGroupedInternalPriorityQueue<T> create(@Nonnull String stateName, @Nonnull org.apache.flink.api.common.typeutils.TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
Creates aKeyGroupedInternalPriorityQueue.- Type Parameters:
T- type of the stored elements.- Parameters:
stateName- unique name for associated with this queue.byteOrderedElementSerializer- a serializer that with a format that is lexicographically ordered in alignment with elementPriorityComparator.allowFutureMetadataUpdates- whether allow metadata to update in the future or not.- Returns:
- the queue with the specified unique name.
-
-