Uses of Class
org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
-
Packages that use KeyGroupStatePartitionStreamProvider Package Description org.apache.flink.runtime.state org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state -
-
Uses of KeyGroupStatePartitionStreamProvider in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return types with arguments of type KeyGroupStatePartitionStreamProvider Modifier and Type Method Description Iterable<KeyGroupStatePartitionStreamProvider>
StateInitializationContext. getRawKeyedStateInputs()
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to this operator.Iterable<KeyGroupStatePartitionStreamProvider>
StateInitializationContextImpl. getRawKeyedStateInputs()
Constructor parameters in org.apache.flink.runtime.state with type arguments of type KeyGroupStatePartitionStreamProvider Constructor Description StateInitializationContextImpl(Long restoredCheckpointId, org.apache.flink.api.common.state.OperatorStateStore operatorStateStore, org.apache.flink.api.common.state.KeyedStateStore keyedStateStore, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs, Iterable<StatePartitionStreamProvider> rawOperatorStateInputs)
-
Uses of KeyGroupStatePartitionStreamProvider in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type KeyGroupStatePartitionStreamProvider Modifier and Type Method Description org.apache.flink.util.CloseableIterable<KeyGroupStatePartitionStreamProvider>
StreamOperatorStateContext. rawKeyedStateInputs()
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to this operator.protected org.apache.flink.util.CloseableIterable<KeyGroupStatePartitionStreamProvider>
StreamTaskStateInitializerImpl. rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives, StateObject.StateObjectSizeStatsCollector statsCollector)
-
Uses of KeyGroupStatePartitionStreamProvider in org.apache.flink.streaming.api.operators.sorted.state
Method parameters in org.apache.flink.streaming.api.operators.sorted.state with type arguments of type KeyGroupStatePartitionStreamProvider 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)
-