Uses of Class
org.apache.flink.runtime.state.KeyGroupRange
-
Packages that use KeyGroupRange Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.jobmaster org.apache.flink.runtime.query org.apache.flink.runtime.scheduler org.apache.flink.runtime.scheduler.adaptive org.apache.flink.runtime.scheduler.adaptive.allocator org.apache.flink.runtime.state org.apache.flink.runtime.state.changelog org.apache.flink.runtime.state.changelog.inmemory 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.restore org.apache.flink.runtime.state.v2.adaptor org.apache.flink.runtime.taskexecutor.rpc org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state -
-
Uses of KeyGroupRange in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type KeyGroupRange Modifier and Type Method Description static List<KeyGroupRange>
StateAssignmentOperation. createKeyGroupPartitions(int numberKeyGroups, int parallelism)
Groups the available set of key groups into key group partitions.Methods in org.apache.flink.runtime.checkpoint with parameters of type KeyGroupRange Modifier and Type Method Description static void
StateAssignmentOperation. extractIntersectingState(Collection<? extends KeyedStateHandle> originalSubtaskStateHandles, KeyGroupRange rangeToExtract, List<KeyedStateHandle> extractedStateCollector)
Extracts certain key group ranges from the given state handles and adds them to the collector.static List<KeyedStateHandle>
StateAssignmentOperation. getManagedKeyedStateHandles(OperatorState operatorState, KeyGroupRange subtaskKeyGroupRange)
CollectmanagedKeyedStateHandles
which have intersection with givenKeyGroupRange
fromoperatorState
.static List<KeyedStateHandle>
StateAssignmentOperation. getRawKeyedStateHandles(OperatorState operatorState, KeyGroupRange subtaskKeyGroupRange)
-
Uses of KeyGroupRange in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type KeyGroupRange Modifier and Type Method Description CompletableFuture<Acknowledge>
JobMaster. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
CompletableFuture<Acknowledge>
KvStateRegistryGateway. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
Notifies that queryable state has been registered.CompletableFuture<Acknowledge>
JobMaster. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
CompletableFuture<Acknowledge>
KvStateRegistryGateway. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
Notifies that queryable state has been unregistered. -
Uses of KeyGroupRange in org.apache.flink.runtime.query
Methods in org.apache.flink.runtime.query with parameters of type KeyGroupRange Modifier and Type Method Description void
KvStateLocationRegistry. notifyKvStateRegistered(JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
Notifies the registry about a registered KvState instance.void
KvStateRegistryListener. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId)
Notifies the listener about a registered KvState instance.void
KvStateLocationRegistry. notifyKvStateUnregistered(JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
Notifies the registry about an unregistered KvState instance.void
KvStateRegistryListener. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
Notifies the listener about an unregistered KvState instance.void
KvStateLocation. registerKvState(KeyGroupRange keyGroupRange, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateAddress)
Registers a KvState instance for the given key group index.org.apache.flink.queryablestate.KvStateID
KvStateRegistry. registerKvState(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, InternalKvState<?,?,?> kvState, ClassLoader userClassLoader)
Registers the KvState instance and returns the assigned ID.void
TaskKvStateRegistry. registerKvState(KeyGroupRange keyGroupRange, String registrationName, InternalKvState<?,?,?> kvState, ClassLoader userClassLoader)
Registers the KvState instance at the KvStateRegistry.void
KvStateRegistry. unregisterKvState(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId)
Unregisters the KvState instance identified by the given KvStateID. -
Uses of KeyGroupRange in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type KeyGroupRange Modifier and Type Method Description void
KvStateHandler. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
SchedulerBase. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
SchedulerNG. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
KvStateHandler. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
void
SchedulerBase. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
void
SchedulerNG. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
-
Uses of KeyGroupRange in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type KeyGroupRange Modifier and Type Method Description void
AdaptiveScheduler. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
AdaptiveScheduler. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
-
Uses of KeyGroupRange in org.apache.flink.runtime.scheduler.adaptive.allocator
Methods in org.apache.flink.runtime.scheduler.adaptive.allocator that return KeyGroupRange Modifier and Type Method Description KeyGroupRange
JobAllocationsInformation.VertexAllocationInformation. getKeyGroupRange()
Constructors in org.apache.flink.runtime.scheduler.adaptive.allocator with parameters of type KeyGroupRange Constructor Description VertexAllocationInformation(AllocationID allocationID, JobVertexID jobVertexID, KeyGroupRange keyGroupRange, long stateSizeInBytes)
-
Uses of KeyGroupRange in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state declared as KeyGroupRange Modifier and Type Field Description static KeyGroupRange
KeyGroupRange. EMPTY_KEY_GROUP_RANGE
The empty key-groupprotected KeyGroupRange
AbstractIncrementalStateHandle. keyGroupRange
The key-group range covered by this state handle.protected KeyGroupRange
AbstractKeyedStateBackend. keyGroupRange
Range of key-groups for which this backend is responsible.protected KeyGroupRange
AbstractKeyedStateBackendBuilder. keyGroupRange
Methods in org.apache.flink.runtime.state that return KeyGroupRange Modifier and Type Method Description static KeyGroupRange
KeyGroupRangeAssignment. computeKeyGroupRangeForOperatorIndex(int maxParallelism, int parallelism, int operatorIndex)
Computes the range of key-groups that are assigned to a given operator under the given parallelism and maximum parallelism.KeyGroupRange
KeyGroupRange. getIntersection(KeyGroupRange other)
Create a range that represent the intersection between this range and the given range.KeyGroupRange
AbstractIncrementalStateHandle. getKeyGroupRange()
KeyGroupRange
AbstractKeyedStateBackend. getKeyGroupRange()
KeyGroupRange
AsyncKeyedStateBackend. getKeyGroupRange()
Returns the key groups which this state backend is responsible for.KeyGroupRange
CheckpointableKeyedStateBackend. getKeyGroupRange()
Returns the key groups which this state backend is responsible for.KeyGroupRange
FullSnapshotResources. getKeyGroupRange()
Returns theKeyGroupRange
of this snapshot.KeyGroupRange
InternalKeyContext. getKeyGroupRange()
Returns the key groups for this backend.KeyGroupRange
InternalKeyContextImpl. getKeyGroupRange()
KeyGroupRange
KeyedStateBackendParametersImpl. getKeyGroupRange()
KeyGroupRange
KeyedStateHandle. getKeyGroupRange()
Returns the range of the key groups contained in the state.KeyGroupRange
KeyGroupRangeOffsets. getKeyGroupRange()
KeyGroupRange
KeyGroupsStateHandle. getKeyGroupRange()
KeyGroupRange
StateBackend.KeyedStateBackendParameters. getKeyGroupRange()
static KeyGroupRange
KeyGroupRange. of(int startKeyGroup, int endKeyGroup)
Factory method that also handles creation of empty key-groups.Methods in org.apache.flink.runtime.state with parameters of type KeyGroupRange Modifier and Type Method Description KeyedStateHandle
AbstractIncrementalStateHandle. getIntersection(KeyGroupRange keyGroupRange)
KeyedStateHandle
KeyedStateHandle. getIntersection(KeyGroupRange keyGroupRange)
Returns a state over a range that is the intersection between this handle's key-group range and the provided key-group range.KeyGroupRange
KeyGroupRange. getIntersection(KeyGroupRange other)
Create a range that represent the intersection between this range and the given range.KeyGroupRangeOffsets
KeyGroupRangeOffsets. getIntersection(KeyGroupRange keyGroupRange)
Returns a key-group range with offsets which is the intersection of the internal key-group range with the given key-group range.KeyGroupsStateHandle
KeyGroupsSavepointStateHandle. getIntersection(KeyGroupRange keyGroupRange)
KeyGroupsStateHandle
KeyGroupsStateHandle. getIntersection(KeyGroupRange keyGroupRange)
static IllegalArgumentException
KeyGroupRangeOffsets. newIllegalKeyGroupException(int keyGroup, KeyGroupRange keyGroupRange)
static IncrementalRemoteKeyedStateHandle
IncrementalRemoteKeyedStateHandle. restore(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState, StreamStateHandle metaStateHandle, long persistedSizeOfThisCheckpoint, StateHandleID stateHandleId)
Constructors in org.apache.flink.runtime.state with parameters of type KeyGroupRange Constructor Description AbstractIncrementalStateHandle(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, StreamStateHandle metaStateHandle, StateHandleID stateHandleId)
AbstractKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, int numberOfKeyGroups, KeyGroupRange keyGroupRange, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
HeapPriorityQueuesManager(Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates, HeapPriorityQueueSetFactory priorityQueueSetFactory, KeyGroupRange keyGroupRange, int numberOfKeyGroups)
IncrementalLocalKeyedStateHandle(UUID backendIdentifier, long checkpointId, DirectoryStateHandle directoryStateHandle, KeyGroupRange keyGroupRange, StreamStateHandle metaDataState, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState)
IncrementalRemoteKeyedStateHandle(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState, StreamStateHandle metaStateHandle)
IncrementalRemoteKeyedStateHandle(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState, StreamStateHandle metaStateHandle, long persistedSizeOfThisCheckpoint)
IncrementalRemoteKeyedStateHandle(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState, StreamStateHandle metaStateHandle, long persistedSizeOfThisCheckpoint, StateHandleID stateHandleId)
InternalKeyContextImpl(KeyGroupRange keyGroupRange, int numberOfKeyGroups)
KeyedStateBackendParametersImpl(Environment env, org.apache.flink.api.common.JobID jobID, String operatorIdentifier, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, int numberOfKeyGroups, KeyGroupRange keyGroupRange, TaskKvStateRegistry kvStateRegistry, TtlTimeProvider ttlTimeProvider, org.apache.flink.metrics.MetricGroup metricGroup, Collection<KeyedStateHandle> stateHandles, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
KeyedStateBackendParametersImpl(Environment env, org.apache.flink.api.common.JobID jobID, String operatorIdentifier, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, int numberOfKeyGroups, KeyGroupRange keyGroupRange, TaskKvStateRegistry kvStateRegistry, TtlTimeProvider ttlTimeProvider, org.apache.flink.metrics.MetricGroup metricGroup, StateBackend.CustomInitializationMetrics customInitializationMetrics, Collection<KeyedStateHandle> stateHandles, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry, double managedMemoryFraction)
KeyedStateCheckpointOutputStream(CheckpointStateOutputStream delegate, KeyGroupRange keyGroupRange)
KeyGroupPartitioner(T[] partitioningSource, int numberOfElements, T[] partitioningDestination, KeyGroupRange keyGroupRange, int totalKeyGroups, KeyExtractorFunction<T> keyExtractorFunction, KeyGroupPartitioner.ElementWriterFunction<T> elementWriterFunction)
Creates a newKeyGroupPartitioner
.KeyGroupRangeOffsets(KeyGroupRange keyGroupRange)
Creates key-group range with offsets for the given key-group range, where all offsets are initially zero.KeyGroupRangeOffsets(KeyGroupRange keyGroupRange, long[] offsets)
Creates key-group range with offsets from the given key-group range.StateSnapshotContextSynchronousImpl(long checkpointId, long checkpointTimestamp, CheckpointStreamFactory streamFactory, KeyGroupRange keyGroupRange, org.apache.flink.core.fs.CloseableRegistry closableRegistry)
-
Uses of KeyGroupRange in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog that return KeyGroupRange Modifier and Type Method Description KeyGroupRange
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. getKeyGroupRange()
KeyGroupRange
ChangelogStateBackendLocalHandle. getKeyGroupRange()
KeyGroupRange
ChangelogStateHandleStreamImpl. getKeyGroupRange()
Methods in org.apache.flink.runtime.state.changelog with parameters of type KeyGroupRange Modifier and Type Method Description StateChangelogWriter<Handle>
StateChangelogStorage. createWriter(String operatorID, KeyGroupRange keyGroupRange, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor)
KeyedStateHandle
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. getIntersection(KeyGroupRange keyGroupRange)
KeyedStateHandle
ChangelogStateBackendLocalHandle. getIntersection(KeyGroupRange keyGroupRange)
KeyedStateHandle
ChangelogStateHandleStreamImpl. getIntersection(KeyGroupRange keyGroupRange)
static ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. restore(List<KeyedStateHandle> materialized, List<ChangelogStateHandle> nonMaterialized, KeyGroupRange keyGroupRange, long checkpointId, long materializationID, long persistedSizeOfThisCheckpoint, StateHandleID stateHandleId)
static ChangelogStateHandleStreamImpl
ChangelogStateHandleStreamImpl. restore(List<org.apache.flink.api.java.tuple.Tuple2<StreamStateHandle,Long>> handlesAndOffsets, KeyGroupRange keyGroupRange, long size, long incrementalSize, String storageIdentifier, StateHandleID stateHandleID)
Constructors in org.apache.flink.runtime.state.changelog with parameters of type KeyGroupRange Constructor Description ChangelogStateBackendHandleImpl(List<KeyedStateHandle> materialized, List<ChangelogStateHandle> nonMaterialized, KeyGroupRange keyGroupRange, long checkpointId, long materializationID, long persistedSizeOfThisCheckpoint)
ChangelogStateHandleStreamImpl(List<org.apache.flink.api.java.tuple.Tuple2<StreamStateHandle,Long>> handlesAndOffsets, KeyGroupRange keyGroupRange, long size, long incrementalSize, String storageIdentifier)
-
Uses of KeyGroupRange in org.apache.flink.runtime.state.changelog.inmemory
Methods in org.apache.flink.runtime.state.changelog.inmemory that return KeyGroupRange Modifier and Type Method Description KeyGroupRange
InMemoryChangelogStateHandle. getKeyGroupRange()
Methods in org.apache.flink.runtime.state.changelog.inmemory with parameters of type KeyGroupRange Modifier and Type Method Description org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogWriter
InMemoryStateChangelogStorage. createWriter(String operatorID, KeyGroupRange keyGroupRange, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor)
KeyedStateHandle
InMemoryChangelogStateHandle. getIntersection(KeyGroupRange keyGroupRange)
static InMemoryChangelogStateHandle
InMemoryChangelogStateHandle. restore(List<StateChange> changes, SequenceNumber from, SequenceNumber to, KeyGroupRange keyGroupRange, StateHandleID stateHandleId)
Constructors in org.apache.flink.runtime.state.changelog.inmemory with parameters of type KeyGroupRange Constructor Description InMemoryChangelogStateHandle(List<StateChange> changes, SequenceNumber from, SequenceNumber to, KeyGroupRange keyGroupRange)
-
Uses of KeyGroupRange in org.apache.flink.runtime.state.heap
Fields in org.apache.flink.runtime.state.heap declared as KeyGroupRange Modifier and Type Field Description protected KeyGroupRange
StateTable. keyGroupRange
The current key group range.Constructors in org.apache.flink.runtime.state.heap with parameters of type KeyGroupRange Constructor Description HeapKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, int numberOfKeyGroups, KeyGroupRange keyGroupRange, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, LocalRecoveryConfig localRecoveryConfig, HeapPriorityQueueSetFactory priorityQueueSetFactory, boolean asynchronousSnapshots, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
HeapKeyValueStateIterator(KeyGroupRange keyGroupRange, org.apache.flink.api.common.typeutils.TypeSerializer<?> keySerializer, int totalKeyGroups, Map<org.apache.flink.runtime.state.heap.StateUID,Integer> stateNamesToId, Map<org.apache.flink.runtime.state.heap.StateUID,StateSnapshot> stateSnapshots)
HeapPriorityQueueSet(PriorityComparator<T> elementPriorityComparator, KeyExtractorFunction<T> keyExtractor, int minimumCapacity, KeyGroupRange keyGroupRange, int totalNumberOfKeyGroups)
Creates an emptyHeapPriorityQueueSet
with the requested initial capacity.HeapPriorityQueueSetFactory(KeyGroupRange keyGroupRange, int totalKeyGroups, int minimumCapacity)
HeapPriorityQueueSnapshotRestoreWrapper(HeapPriorityQueueSet<T> priorityQueue, RegisteredPriorityQueueStateBackendMetaInfo<T> metaInfo, KeyExtractorFunction<T> keyExtractorFunction, KeyGroupRange localKeyGroupRange, int totalKeyGroups)
KeyGroupPartitionedPriorityQueue(KeyExtractorFunction<T> keyExtractor, PriorityComparator<T> elementPriorityComparator, KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T,PQ> orderedCacheFactory, KeyGroupRange keyGroupRange, int totalKeyGroups)
-
Uses of KeyGroupRange in org.apache.flink.runtime.state.restore
Constructors in org.apache.flink.runtime.state.restore with parameters of type KeyGroupRange Constructor Description FullSnapshotRestoreOperation(KeyGroupRange keyGroupRange, ClassLoader userCodeClassLoader, Collection<KeyedStateHandle> restoreStateHandles, StateSerializerProvider<K> keySerializerProvider)
-
Uses of KeyGroupRange in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor that return KeyGroupRange Modifier and Type Method Description KeyGroupRange
AsyncKeyedStateBackendAdaptor. getKeyGroupRange()
-
Uses of KeyGroupRange in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc with parameters of type KeyGroupRange Modifier and Type Method Description void
RpcKvStateRegistryListener. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId)
void
RpcKvStateRegistryListener. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
-
Uses of KeyGroupRange in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type KeyGroupRange Modifier and Type Method Description <K> InternalTimeServiceManager<K>
InternalTimeServiceManager.Provider. create(TaskIOMetricGroup taskIOMetricGroup, PriorityQueueSetFactory factory, KeyGroupRange keyGroupRange, ClassLoader userClassloader, KeyContext keyContext, ProcessingTimeService processingTimeService, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates, StreamTaskCancellationContext cancellationContext)
static <K> InternalTimeServiceManagerImpl<K>
InternalTimeServiceManagerImpl. create(TaskIOMetricGroup taskIOMetricGroup, PriorityQueueSetFactory factory, KeyGroupRange keyGroupRange, ClassLoader userClassloader, KeyContext keyContext, ProcessingTimeService processingTimeService, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates, StreamTaskCancellationContext cancellationContext)
A factory method for creating theInternalTimeServiceManagerImpl
. -
Uses of KeyGroupRange in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state that return KeyGroupRange Modifier and Type Method Description KeyGroupRange
BatchExecutionKeyedStateBackend. getKeyGroupRange()
Methods in org.apache.flink.streaming.api.operators.sorted.state with parameters of type KeyGroupRange Modifier and Type Method Description static <K> InternalTimeServiceManager<K>
BatchExecutionInternalTimeServiceManager. create(TaskIOMetricGroup taskIOMetricGroup, PriorityQueueSetFactory factory, KeyGroupRange keyGroupRange, ClassLoader userClassloader, KeyContext keyContext, ProcessingTimeService processingTimeService, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates, StreamTaskCancellationContext cancellationContext)
Constructors in org.apache.flink.streaming.api.operators.sorted.state with parameters of type KeyGroupRange Constructor Description BatchExecutionKeyedStateBackend(org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, KeyGroupRange keyGroupRange, org.apache.flink.api.common.ExecutionConfig executionConfig)
-