Uses of Class
org.apache.flink.runtime.state.StateHandleID
-
Packages that use StateHandleID Package Description org.apache.flink.runtime.state org.apache.flink.runtime.state.changelog org.apache.flink.runtime.state.changelog.inmemory -
-
Uses of StateHandleID in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state declared as StateHandleID Modifier and Type Field Description protected StateHandleID
AbstractIncrementalStateHandle. stateHandleId
Unique id for this state handle.Methods in org.apache.flink.runtime.state that return StateHandleID Modifier and Type Method Description StateHandleID
AbstractIncrementalStateHandle. getStateHandleId()
StateHandleID
KeyedStateHandle. getStateHandleId()
Returns a unique state handle id to distinguish with other keyed state handles.StateHandleID
KeyGroupsStateHandle. getStateHandleId()
static StateHandleID
StateHandleID. randomStateHandleId()
Methods in org.apache.flink.runtime.state with parameters of type StateHandleID 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)
static KeyGroupsStateHandle
KeyGroupsStateHandle. restore(KeyGroupRangeOffsets groupRangeOffsets, StreamStateHandle streamStateHandle, StateHandleID stateHandleId)
Constructors in org.apache.flink.runtime.state with parameters of type StateHandleID Constructor Description AbstractIncrementalStateHandle(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, StreamStateHandle metaStateHandle, StateHandleID stateHandleId)
EmptyDiscardStateObjectForRegister(StateHandleID stateHandleID)
IncrementalRemoteKeyedStateHandle(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState, StreamStateHandle metaStateHandle, long persistedSizeOfThisCheckpoint, StateHandleID stateHandleId)
SharedStateRegistryKey(String prefix, StateHandleID stateHandleID)
-
Uses of StateHandleID in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog that return StateHandleID Modifier and Type Method Description StateHandleID
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl. getStateHandleId()
StateHandleID
ChangelogStateBackendLocalHandle. getStateHandleId()
StateHandleID
ChangelogStateHandleStreamImpl. getStateHandleId()
Methods in org.apache.flink.runtime.state.changelog with parameters of type StateHandleID Modifier and Type Method Description 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<Tuple2<StreamStateHandle,Long>> handlesAndOffsets, KeyGroupRange keyGroupRange, long size, long incrementalSize, String storageIdentifier, StateHandleID stateHandleID)
-
Uses of StateHandleID in org.apache.flink.runtime.state.changelog.inmemory
Methods in org.apache.flink.runtime.state.changelog.inmemory that return StateHandleID Modifier and Type Method Description StateHandleID
InMemoryChangelogStateHandle. getStateHandleId()
Methods in org.apache.flink.runtime.state.changelog.inmemory with parameters of type StateHandleID Modifier and Type Method Description static InMemoryChangelogStateHandle
InMemoryChangelogStateHandle. restore(List<StateChange> changes, SequenceNumber from, SequenceNumber to, KeyGroupRange keyGroupRange, StateHandleID stateHandleId)
-