Uses of Interface
org.apache.flink.runtime.state.StreamStateHandle
-
-
Uses of StreamStateHandle in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return StreamStateHandle Modifier and Type Method Description StreamStateHandle
CompletedCheckpoint. getMetadataHandle()
-
Uses of StreamStateHandle in org.apache.flink.runtime.checkpoint.channel
Methods in org.apache.flink.runtime.checkpoint.channel with parameters of type StreamStateHandle Modifier and Type Method Description void
ChannelStatePendingResult. finishResult(StreamStateHandle stateHandle)
-
Uses of StreamStateHandle in org.apache.flink.runtime.checkpoint.filemerging
Methods in org.apache.flink.runtime.checkpoint.filemerging with parameters of type StreamStateHandle Modifier and Type Method Description boolean
FileMergingSnapshotManager. couldReusePreviousStateHandle(StreamStateHandle stateHandle)
Check whether previous state handles could further be reused considering the space amplification.boolean
FileMergingSnapshotManagerBase. couldReusePreviousStateHandle(StreamStateHandle stateHandle)
static boolean
FileMergingSnapshotManager. isFileMergingHandle(StreamStateHandle handle)
Method parameters in org.apache.flink.runtime.checkpoint.filemerging with type arguments of type StreamStateHandle Modifier and Type Method Description void
FileMergingSnapshotManager. reusePreviousStateHandle(long checkpointId, Collection<? extends StreamStateHandle> stateHandles)
A callback method which is called when previous state handles are reused by following checkpoint(s).void
FileMergingSnapshotManagerBase. reusePreviousStateHandle(long checkpointId, Collection<? extends StreamStateHandle> stateHandles)
-
Uses of StreamStateHandle in org.apache.flink.runtime.checkpoint.metadata
Methods in org.apache.flink.runtime.checkpoint.metadata that return StreamStateHandle Modifier and Type Method Description static StreamStateHandle
MetadataV3Serializer. deserializeStreamStateHandle(DataInputStream dis)
Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type StreamStateHandle Modifier and Type Method Description static void
MetadataV3Serializer. serializeStreamStateHandle(StreamStateHandle stateHandle, DataOutputStream dos)
-
Uses of StreamStateHandle in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state with type parameters of type StreamStateHandle Modifier and Type Class Description class
NonClosingCheckpointOutputStream<T extends StreamStateHandle>
Abstract class to implement custom checkpoint output streams which should not be closable for user code.Subinterfaces of StreamStateHandle in org.apache.flink.runtime.state Modifier and Type Interface Description interface
OperatorStateHandle
Interface of a state handle for operator state.Classes in org.apache.flink.runtime.state that implement StreamStateHandle Modifier and Type Class Description class
KeyGroupsSavepointStateHandle
AKeyGroupsStateHandle
that describes a savepoint in the unified format.class
KeyGroupsStateHandle
A handle to the partitioned stream operator state after it has been checkpointed.class
OperatorStreamStateHandle
State handle for partitionable operator state.class
PlaceholderStreamStateHandle
A placeholder state handle for shared state that will replaced by an original that was created in a previous checkpoint.class
RetrievableStreamStateHandle<T extends Serializable>
Wrapper around aStreamStateHandle
to make the referenced state object retrievable trough a simple get call.static class
SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
An object with empty discardState for registering.Fields in org.apache.flink.runtime.state declared as StreamStateHandle Modifier and Type Field Description protected StreamStateHandle
AbstractIncrementalStateHandle. metaStateHandle
Primary meta data state of the incremental checkpoint.Methods in org.apache.flink.runtime.state that return StreamStateHandle Modifier and Type Method Description abstract StreamStateHandle
CheckpointStateOutputStream. closeAndGetHandle()
Closes the stream and gets a state handle that can create an input stream producing the data written to this stream.StreamStateHandle
DuplicatingCheckpointOutputStream. closeAndGetHandle()
StreamStateHandle
DuplicatingCheckpointOutputStream. closeAndGetPrimaryHandle()
Returns the state handle from theDuplicatingCheckpointOutputStream.primaryOutputStream
.StreamStateHandle
DuplicatingCheckpointOutputStream. closeAndGetSecondaryHandle()
Returns the state handle from theDuplicatingCheckpointOutputStream.secondaryOutputStream
.StreamStateHandle
AbstractChannelStateHandle. getDelegate()
StreamStateHandle
KeyGroupsStateHandle. getDelegateStateHandle()
StreamStateHandle
OperatorStateHandle. getDelegateStateHandle()
Returns the underlying stream state handle that points to the state data.StreamStateHandle
OperatorStreamStateHandle. getDelegateStateHandle()
StreamStateHandle
IncrementalKeyedStateHandle.HandleAndLocalPath. getHandle()
StreamStateHandle
CompletedCheckpointStorageLocation. getMetadataHandle()
Gets the state handle to the checkpoint's metadata.StreamStateHandle
AbstractIncrementalStateHandle. getMetaDataStateHandle()
StreamStateHandle
IncrementalKeyedStateHandle. getMetaDataStateHandle()
default StreamStateHandle
SharedStateRegistry. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle state, long checkpointID)
Shortcut forSharedStateRegistry.registerReference(SharedStateRegistryKey, StreamStateHandle, long, boolean)
with preventDiscardingCreatedCheckpoint = false.StreamStateHandle
SharedStateRegistry. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle state, long checkpointID, boolean preventDiscardingCreatedCheckpoint)
Register a reference to the given shared state in the registry.StreamStateHandle
SharedStateRegistryImpl. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle newHandle, long checkpointID, boolean preventDiscardingCreatedCheckpoint)
Methods in org.apache.flink.runtime.state that return types with arguments of type StreamStateHandle Modifier and Type Method Description SnapshotResult<StreamStateHandle>
CheckpointStreamWithResultProvider. closeAndFinalizeCheckpointStreamResult()
Closes the stream ans returns a snapshot result with the stream handle(s).SnapshotResult<StreamStateHandle>
CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream. closeAndFinalizeCheckpointStreamResult()
SnapshotResult<StreamStateHandle>
CheckpointStreamWithResultProvider.PrimaryStreamOnly. closeAndFinalizeCheckpointStreamResult()
static Stream<StreamStateHandle>
AbstractChannelStateHandle. collectUniqueDelegates(Stream<StateObjectCollection<? extends AbstractChannelStateHandle<?>>> collections)
List<StreamStateHandle>
CheckpointStateToolset. duplicate(List<StreamStateHandle> stateHandle)
DuplicatesStreamStateHandles
into the path embedded inside of the class.List<StreamStateHandle>
CheckpointStreamFactory. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)
DuplicatesStreamStateHandle
into the path corresponding to * the givenCheckpointedStateScope
.List<StreamStateHandle>
NotDuplicatingCheckpointStateToolset. duplicate(List<StreamStateHandle> stateHandle)
Stream<StreamStateHandle>
IncrementalRemoteKeyedStateHandle. streamSubHandles()
Methods in org.apache.flink.runtime.state with parameters of type StreamStateHandle Modifier and Type Method Description boolean
CheckpointStateToolset. canFastDuplicate(StreamStateHandle stateHandle)
Tells if we can duplicate the givenStreamStateHandle
.boolean
CheckpointStreamFactory. canFastDuplicate(StreamStateHandle stateHandle, CheckpointedStateScope scope)
Tells if we can duplicate the givenStreamStateHandle
into the path corresponding to the givenCheckpointedStateScope
.boolean
NotDuplicatingCheckpointStateToolset. canFastDuplicate(StreamStateHandle stateHandle)
default boolean
CheckpointStreamFactory. couldReuseStateHandle(StreamStateHandle stateHandle)
A pre-check hook before the checkpoint writer want to reuse a state handle, if this returns false, it is not recommended for the writer to rewrite the state file considering the space amplification.KeyedStateHandle
CheckpointStreamWithResultProvider.KeyedStateHandleFactory. create(KeyGroupRangeOffsets keyGroupRangeOffsets, StreamStateHandle streamStateHandle)
static SharedStateRegistryKey
SharedStateRegistryKey. forStreamStateHandle(StreamStateHandle handle)
Create a unique key based on physical id.static IncrementalKeyedStateHandle.HandleAndLocalPath
IncrementalKeyedStateHandle.HandleAndLocalPath. of(StreamStateHandle handle, String localPath)
default StreamStateHandle
SharedStateRegistry. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle state, long checkpointID)
Shortcut forSharedStateRegistry.registerReference(SharedStateRegistryKey, StreamStateHandle, long, boolean)
with preventDiscardingCreatedCheckpoint = false.StreamStateHandle
SharedStateRegistry. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle state, long checkpointID, boolean preventDiscardingCreatedCheckpoint)
Register a reference to the given shared state in the registry.StreamStateHandle
SharedStateRegistryImpl. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle newHandle, long checkpointID, boolean preventDiscardingCreatedCheckpoint)
void
IncrementalKeyedStateHandle.HandleAndLocalPath. replaceHandle(StreamStateHandle registryReturned)
Replace the StreamStateHandle with the registry returned one.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)
Method parameters in org.apache.flink.runtime.state with type arguments of type StreamStateHandle Modifier and Type Method Description List<StreamStateHandle>
CheckpointStateToolset. duplicate(List<StreamStateHandle> stateHandle)
DuplicatesStreamStateHandles
into the path embedded inside of the class.List<StreamStateHandle>
CheckpointStreamFactory. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)
DuplicatesStreamStateHandle
into the path corresponding to * the givenCheckpointedStateScope
.List<StreamStateHandle>
NotDuplicatingCheckpointStateToolset. duplicate(List<StreamStateHandle> stateHandle)
default void
CheckpointStreamFactory. reusePreviousStateHandle(Collection<? extends StreamStateHandle> previousHandle)
A callback method when some previous handle is reused.static SnapshotResult<KeyedStateHandle>
CheckpointStreamWithResultProvider. toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle> snapshotResult, KeyGroupRangeOffsets keyGroupRangeOffsets, CheckpointStreamWithResultProvider.KeyedStateHandleFactory stateHandleFactory)
Helper method that takes aSnapshotResult
and aKeyGroupRangeOffsets
and creates aSnapshotResult
by combining the key groups offsets with all the present stream state handles. -
Uses of StreamStateHandle in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog that return types with arguments of type StreamStateHandle Modifier and Type Method Description List<org.apache.flink.api.java.tuple.Tuple2<StreamStateHandle,Long>>
ChangelogStateHandleStreamImpl. getHandlesAndOffsets()
Methods in org.apache.flink.runtime.state.changelog with parameters of type StreamStateHandle Modifier and Type Method Description org.apache.flink.util.CloseableIterator<StateChange>
StateChangelogHandleStreamHandleReader.StateChangeIterator. read(StreamStateHandle handle, long offset)
void
LocalChangelogRegistry. register(StreamStateHandle handle, long checkpointID)
Called upon ChangelogKeyedStateBackend#notifyCheckpointComplete.void
LocalChangelogRegistryImpl. register(StreamStateHandle handle, long checkpointID)
Method parameters in org.apache.flink.runtime.state.changelog with type arguments of type StreamStateHandle Modifier and Type Method Description 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)
Constructor parameters in org.apache.flink.runtime.state.changelog with type arguments of type StreamStateHandle Constructor Description ChangelogStateHandleStreamImpl(List<org.apache.flink.api.java.tuple.Tuple2<StreamStateHandle,Long>> handlesAndOffsets, KeyGroupRange keyGroupRange, long size, long incrementalSize, String storageIdentifier)
-
Uses of StreamStateHandle in org.apache.flink.runtime.state.filemerging
Classes in org.apache.flink.runtime.state.filemerging that implement StreamStateHandle Modifier and Type Class Description class
DirectoryStreamStateHandle
This state handle represents a directory, usually used to be registered toSharedStateRegistry
to track the life cycle of the directory.class
EmptyFileMergingOperatorStreamStateHandle
An emptyFileMergingOperatorStreamStateHandle
that is only used as a placeholder to prevent file merging directory from being deleted.class
EmptySegmentFileStateHandle
An emptySegmentFileStateHandle
that is only used as a placeholder.class
FileMergingOperatorStreamStateHandle
AOperatorStreamStateHandle
that works for file merging checkpoints.class
SegmentFileStateHandle
FileStateHandle
for state that was written to a file segment.Constructors in org.apache.flink.runtime.state.filemerging with parameters of type StreamStateHandle Constructor Description EmptyFileMergingOperatorStreamStateHandle(DirectoryStreamStateHandle taskOwnedDirHandle, DirectoryStreamStateHandle sharedDirHandle, Map<String,OperatorStateHandle.StateMetaInfo> stateNameToPartitionOffsets, StreamStateHandle delegateStateHandle)
FileMergingOperatorStreamStateHandle(DirectoryStreamStateHandle taskOwnedDirHandle, DirectoryStreamStateHandle sharedDirHandle, Map<String,OperatorStateHandle.StateMetaInfo> stateNameToPartitionOffsets, StreamStateHandle delegateStateHandle)
-
Uses of StreamStateHandle in org.apache.flink.runtime.state.filesystem
Classes in org.apache.flink.runtime.state.filesystem that implement StreamStateHandle Modifier and Type Class Description class
FileStateHandle
StreamStateHandle
for state that was written to a file stream.class
RelativeFileStateHandle
AStreamStateHandle
for state that was written to a file stream.Methods in org.apache.flink.runtime.state.filesystem that return StreamStateHandle Modifier and Type Method Description StreamStateHandle
FsCheckpointStreamFactory.FsCheckpointStateOutputStream. closeAndGetHandle()
Methods in org.apache.flink.runtime.state.filesystem that return types with arguments of type StreamStateHandle Modifier and Type Method Description List<StreamStateHandle>
FsCheckpointStateToolset. duplicate(List<StreamStateHandle> stateHandles)
List<StreamStateHandle>
FsCheckpointStreamFactory. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)
List<StreamStateHandle>
FsMergingCheckpointStorageLocation. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)
Methods in org.apache.flink.runtime.state.filesystem with parameters of type StreamStateHandle Modifier and Type Method Description boolean
FsCheckpointStateToolset. canFastDuplicate(StreamStateHandle stateHandle)
boolean
FsCheckpointStreamFactory. canFastDuplicate(StreamStateHandle stateHandle, CheckpointedStateScope scope)
boolean
FsMergingCheckpointStorageLocation. canFastDuplicate(StreamStateHandle stateHandle, CheckpointedStateScope scope)
boolean
FsMergingCheckpointStorageLocation. couldReuseStateHandle(StreamStateHandle stateHandle)
Method parameters in org.apache.flink.runtime.state.filesystem with type arguments of type StreamStateHandle Modifier and Type Method Description List<StreamStateHandle>
FsCheckpointStateToolset. duplicate(List<StreamStateHandle> stateHandles)
List<StreamStateHandle>
FsCheckpointStreamFactory. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)
List<StreamStateHandle>
FsMergingCheckpointStorageLocation. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)
void
FsMergingCheckpointStorageLocation. reusePreviousStateHandle(Collection<? extends StreamStateHandle> previousHandle)
-
Uses of StreamStateHandle in org.apache.flink.runtime.state.memory
Classes in org.apache.flink.runtime.state.memory that implement StreamStateHandle Modifier and Type Class Description class
ByteStreamStateHandle
A state handle that contains stream state in a byte array.Methods in org.apache.flink.runtime.state.memory that return StreamStateHandle Modifier and Type Method Description StreamStateHandle
MemCheckpointStreamFactory.MemoryCheckpointOutputStream. closeAndGetHandle()
Methods in org.apache.flink.runtime.state.memory that return types with arguments of type StreamStateHandle Modifier and Type Method Description List<StreamStateHandle>
MemCheckpointStreamFactory. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)
Methods in org.apache.flink.runtime.state.memory with parameters of type StreamStateHandle Modifier and Type Method Description boolean
MemCheckpointStreamFactory. canFastDuplicate(StreamStateHandle stateHandle, CheckpointedStateScope scope)
Method parameters in org.apache.flink.runtime.state.memory with type arguments of type StreamStateHandle Modifier and Type Method Description List<StreamStateHandle>
MemCheckpointStreamFactory. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)
-