Uses of Interface
org.apache.flink.runtime.state.PriorityComparable
-
Packages that use PriorityComparable Package Description 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.runtime.state.v2.adaptor org.apache.flink.state.changelog org.apache.flink.state.changelog.restore org.apache.flink.state.forst org.apache.flink.state.forst.sync org.apache.flink.state.rocksdb org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state -
-
Uses of PriorityComparable in org.apache.flink.runtime.source.coordinator
Classes in org.apache.flink.runtime.source.coordinator that implement PriorityComparable Modifier and Type Class Description static class
SourceCoordinator.WatermarkElement
The watermark element forHeapPriorityQueue
. -
Uses of PriorityComparable in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state with type parameters of type PriorityComparable Modifier and Type Field Description static PriorityComparator<? extends PriorityComparable<Object>>
PriorityComparator. FOR_PRIORITY_COMPARABLE_OBJECTS
Methods in org.apache.flink.runtime.state with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>PriorityQueueSetFactory. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
Creates aKeyGroupedInternalPriorityQueue
.default <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>PriorityQueueSetFactory. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
Creates aKeyGroupedInternalPriorityQueue
.<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>HeapPriorityQueuesManager. createOrUpdate(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>HeapPriorityQueuesManager. createOrUpdate(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
static <T extends PriorityComparable<?>>
PriorityComparator<T>PriorityComparator. forPriorityComparableObjects()
-
Uses of PriorityComparable in org.apache.flink.runtime.state.heap
Methods in org.apache.flink.runtime.state.heap with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>HeapKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>HeapKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
HeapPriorityQueueSet<T>HeapPriorityQueueSetFactory. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
-
Uses of PriorityComparable in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>AsyncKeyedStateBackendAdaptor. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>AsyncKeyedStateBackendAdaptor. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
-
Uses of PriorityComparable in org.apache.flink.state.changelog
Methods in org.apache.flink.state.changelog with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ChangelogKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
-
Uses of PriorityComparable in org.apache.flink.state.changelog.restore
Methods in org.apache.flink.state.changelog.restore with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ChangelogMigrationRestoreTarget. createPqState(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ChangelogRestoreTarget. createPqState(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
Creates aKeyGroupedInternalPriorityQueue
which could be retrieved byChangelogRestoreTarget.getExistingState(String, BackendStateType)
in the restore procedure. -
Uses of PriorityComparable in org.apache.flink.state.forst
Methods in org.apache.flink.state.forst with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ForStKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ForStKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
-
Uses of PriorityComparable in org.apache.flink.state.forst.sync
Methods in org.apache.flink.state.forst.sync with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ForStDBPriorityQueueSetFactory. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ForStDBPriorityQueueSetFactory. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ForStSyncKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>ForStSyncKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
-
Uses of PriorityComparable in org.apache.flink.state.rocksdb
Methods in org.apache.flink.state.rocksdb with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>RocksDBKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>RocksDBKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>RocksDBPriorityQueueSetFactory. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>RocksDBPriorityQueueSetFactory. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer, boolean allowFutureMetadataUpdates)
-
Uses of PriorityComparable in org.apache.flink.streaming.api.operators
Subinterfaces of PriorityComparable in org.apache.flink.streaming.api.operators Modifier and Type Interface Description interface
InternalTimer<K,N>
Internal interface for in-flight timers.Classes in org.apache.flink.streaming.api.operators that implement PriorityComparable Modifier and Type Class Description class
TimerHeapInternalTimer<K,N>
Implementation ofInternalTimer
to use with aHeapPriorityQueueSet
. -
Uses of PriorityComparable in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state with type parameters of type PriorityComparable Modifier and Type Method Description <T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>>
KeyGroupedInternalPriorityQueue<T>BatchExecutionKeyedStateBackend. create(String stateName, TypeSerializer<T> byteOrderedElementSerializer)
-