Uses of Class
org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
Packages that use IncrementalRemoteKeyedStateHandle Package Description org.apache.flink.runtime.state org.apache.flink.state.forst org.apache.flink.state.forst.restore org.apache.flink.state.rocksdb -
-
Uses of IncrementalRemoteKeyedStateHandle in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return IncrementalRemoteKeyedStateHandle Modifier and Type Method Description static IncrementalRemoteKeyedStateHandle
IncrementalRemoteKeyedStateHandle. restore(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState, StreamStateHandle metaStateHandle, long persistedSizeOfThisCheckpoint, StateHandleID stateHandleId)
-
Uses of IncrementalRemoteKeyedStateHandle in org.apache.flink.state.forst
Methods in org.apache.flink.state.forst that return IncrementalRemoteKeyedStateHandle Modifier and Type Method Description IncrementalRemoteKeyedStateHandle
StateHandleTransferSpec. getStateHandle()
Constructors in org.apache.flink.state.forst with parameters of type IncrementalRemoteKeyedStateHandle Constructor Description StateHandleTransferSpec(IncrementalRemoteKeyedStateHandle stateHandle, Path transferDestination)
-
Uses of IncrementalRemoteKeyedStateHandle in org.apache.flink.state.forst.restore
Constructor parameters in org.apache.flink.state.forst.restore with type arguments of type IncrementalRemoteKeyedStateHandle Constructor Description ForStIncrementalRestoreOperation(String operatorIdentifier, KeyGroupRange keyGroupRange, CloseableRegistry cancelStreamRegistry, ClassLoader userCodeClassLoader, Map<String,ForStOperationUtils.ForStKvStateInfo> kvStateInformation, StateSerializerProvider<K> keySerializerProvider, ForStResourceContainer optionsContainer, Path forstBasePath, Path instanceRocksDBPath, org.forstdb.DBOptions dbOptions, Function<String,org.forstdb.ColumnFamilyOptions> columnFamilyOptionsFactory, ForStNativeMetricOptions nativeMetricOptions, MetricGroup metricGroup, StateBackend.CustomInitializationMetrics customInitializationMetrics, Collection<IncrementalRemoteKeyedStateHandle> restoreStateHandles)
-
Uses of IncrementalRemoteKeyedStateHandle in org.apache.flink.state.rocksdb
Methods in org.apache.flink.state.rocksdb that return IncrementalRemoteKeyedStateHandle Modifier and Type Method Description IncrementalRemoteKeyedStateHandle
StateHandleDownloadSpec. getStateHandle()
Constructors in org.apache.flink.state.rocksdb with parameters of type IncrementalRemoteKeyedStateHandle Constructor Description StateHandleDownloadSpec(IncrementalRemoteKeyedStateHandle stateHandle, Path downloadDestination)
-