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 StreamStateHandleCompletedCheckpoint. 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 voidChannelStatePendingResult. 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 booleanFileMergingSnapshotManager. couldReusePreviousStateHandle(StreamStateHandle stateHandle)Check whether previous state handles could further be reused considering the space amplification.booleanFileMergingSnapshotManagerBase. couldReusePreviousStateHandle(StreamStateHandle stateHandle)static booleanFileMergingSnapshotManager. isFileMergingHandle(StreamStateHandle handle)Method parameters in org.apache.flink.runtime.checkpoint.filemerging with type arguments of type StreamStateHandle Modifier and Type Method Description voidFileMergingSnapshotManager. reusePreviousStateHandle(long checkpointId, Collection<? extends StreamStateHandle> stateHandles)A callback method which is called when previous state handles are reused by following checkpoint(s).voidFileMergingSnapshotManagerBase. 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 StreamStateHandleMetadataV3Serializer. deserializeStreamStateHandle(DataInputStream dis)Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type StreamStateHandle Modifier and Type Method Description static voidMetadataV3Serializer. 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 classNonClosingCheckpointOutputStream<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 interfaceOperatorStateHandleInterface of a state handle for operator state.Classes in org.apache.flink.runtime.state that implement StreamStateHandle Modifier and Type Class Description classKeyGroupsSavepointStateHandleAKeyGroupsStateHandlethat describes a savepoint in the unified format.classKeyGroupsStateHandleA handle to the partitioned stream operator state after it has been checkpointed.classOperatorStreamStateHandleState handle for partitionable operator state.classPlaceholderStreamStateHandleA placeholder state handle for shared state that will replaced by an original that was created in a previous checkpoint.classRetrievableStreamStateHandle<T extends Serializable>Wrapper around aStreamStateHandleto make the referenced state object retrievable trough a simple get call.static classSharedStateRegistryImpl.EmptyDiscardStateObjectForRegisterAn object with empty discardState for registering.Fields in org.apache.flink.runtime.state declared as StreamStateHandle Modifier and Type Field Description protected StreamStateHandleAbstractIncrementalStateHandle. metaStateHandlePrimary meta data state of the incremental checkpoint.Methods in org.apache.flink.runtime.state that return StreamStateHandle Modifier and Type Method Description abstract StreamStateHandleCheckpointStateOutputStream. closeAndGetHandle()Closes the stream and gets a state handle that can create an input stream producing the data written to this stream.StreamStateHandleDuplicatingCheckpointOutputStream. closeAndGetHandle()StreamStateHandleDuplicatingCheckpointOutputStream. closeAndGetPrimaryHandle()Returns the state handle from theDuplicatingCheckpointOutputStream.primaryOutputStream.StreamStateHandleDuplicatingCheckpointOutputStream. closeAndGetSecondaryHandle()Returns the state handle from theDuplicatingCheckpointOutputStream.secondaryOutputStream.StreamStateHandleAbstractChannelStateHandle. getDelegate()StreamStateHandleKeyGroupsStateHandle. getDelegateStateHandle()StreamStateHandleOperatorStateHandle. getDelegateStateHandle()Returns the underlying stream state handle that points to the state data.StreamStateHandleOperatorStreamStateHandle. getDelegateStateHandle()StreamStateHandleIncrementalKeyedStateHandle.HandleAndLocalPath. getHandle()StreamStateHandleCompletedCheckpointStorageLocation. getMetadataHandle()Gets the state handle to the checkpoint's metadata.StreamStateHandleAbstractIncrementalStateHandle. getMetaDataStateHandle()StreamStateHandleIncrementalKeyedStateHandle. getMetaDataStateHandle()default StreamStateHandleSharedStateRegistry. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle state, long checkpointID)Shortcut forSharedStateRegistry.registerReference(SharedStateRegistryKey, StreamStateHandle, long, boolean)with preventDiscardingCreatedCheckpoint = false.StreamStateHandleSharedStateRegistry. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle state, long checkpointID, boolean preventDiscardingCreatedCheckpoint)Register a reference to the given shared state in the registry.StreamStateHandleSharedStateRegistryImpl. 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)DuplicatesStreamStateHandlesinto the path embedded inside of the class.List<StreamStateHandle>CheckpointStreamFactory. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)DuplicatesStreamStateHandleinto 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 booleanCheckpointStateToolset. canFastDuplicate(StreamStateHandle stateHandle)Tells if we can duplicate the givenStreamStateHandle.booleanCheckpointStreamFactory. canFastDuplicate(StreamStateHandle stateHandle, CheckpointedStateScope scope)Tells if we can duplicate the givenStreamStateHandleinto the path corresponding to the givenCheckpointedStateScope.booleanNotDuplicatingCheckpointStateToolset. canFastDuplicate(StreamStateHandle stateHandle)default booleanCheckpointStreamFactory. 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.KeyedStateHandleCheckpointStreamWithResultProvider.KeyedStateHandleFactory. create(KeyGroupRangeOffsets keyGroupRangeOffsets, StreamStateHandle streamStateHandle)static SharedStateRegistryKeySharedStateRegistryKey. forStreamStateHandle(StreamStateHandle handle)Create a unique key based on physical id.static IncrementalKeyedStateHandle.HandleAndLocalPathIncrementalKeyedStateHandle.HandleAndLocalPath. of(StreamStateHandle handle, String localPath)default StreamStateHandleSharedStateRegistry. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle state, long checkpointID)Shortcut forSharedStateRegistry.registerReference(SharedStateRegistryKey, StreamStateHandle, long, boolean)with preventDiscardingCreatedCheckpoint = false.StreamStateHandleSharedStateRegistry. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle state, long checkpointID, boolean preventDiscardingCreatedCheckpoint)Register a reference to the given shared state in the registry.StreamStateHandleSharedStateRegistryImpl. registerReference(SharedStateRegistryKey registrationKey, StreamStateHandle newHandle, long checkpointID, boolean preventDiscardingCreatedCheckpoint)voidIncrementalKeyedStateHandle.HandleAndLocalPath. replaceHandle(StreamStateHandle registryReturned)Replace the StreamStateHandle with the registry returned one.static IncrementalRemoteKeyedStateHandleIncrementalRemoteKeyedStateHandle. restore(UUID backendIdentifier, KeyGroupRange keyGroupRange, long checkpointId, List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState, List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState, StreamStateHandle metaStateHandle, long persistedSizeOfThisCheckpoint, StateHandleID stateHandleId)static KeyGroupsStateHandleKeyGroupsStateHandle. 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)DuplicatesStreamStateHandlesinto the path embedded inside of the class.List<StreamStateHandle>CheckpointStreamFactory. duplicate(List<StreamStateHandle> stateHandles, CheckpointedStateScope scope)DuplicatesStreamStateHandleinto the path corresponding to * the givenCheckpointedStateScope.List<StreamStateHandle>NotDuplicatingCheckpointStateToolset. duplicate(List<StreamStateHandle> stateHandle)default voidCheckpointStreamFactory. 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 aSnapshotResultand aKeyGroupRangeOffsetsand creates aSnapshotResultby 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)voidLocalChangelogRegistry. register(StreamStateHandle handle, long checkpointID)Called upon ChangelogKeyedStateBackend#notifyCheckpointComplete.voidLocalChangelogRegistryImpl. 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 ChangelogStateHandleStreamImplChangelogStateHandleStreamImpl. 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 classDirectoryStreamStateHandleThis state handle represents a directory, usually used to be registered toSharedStateRegistryto track the life cycle of the directory.classEmptyFileMergingOperatorStreamStateHandleAn emptyFileMergingOperatorStreamStateHandlethat is only used as a placeholder to prevent file merging directory from being deleted.classEmptySegmentFileStateHandleAn emptySegmentFileStateHandlethat is only used as a placeholder.classFileMergingOperatorStreamStateHandleAOperatorStreamStateHandlethat works for file merging checkpoints.classSegmentFileStateHandleFileStateHandlefor 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 classFileStateHandleStreamStateHandlefor state that was written to a file stream.classRelativeFileStateHandleAStreamStateHandlefor state that was written to a file stream.Methods in org.apache.flink.runtime.state.filesystem that return StreamStateHandle Modifier and Type Method Description StreamStateHandleFsCheckpointStreamFactory.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 booleanFsCheckpointStateToolset. canFastDuplicate(StreamStateHandle stateHandle)booleanFsCheckpointStreamFactory. canFastDuplicate(StreamStateHandle stateHandle, CheckpointedStateScope scope)booleanFsMergingCheckpointStorageLocation. canFastDuplicate(StreamStateHandle stateHandle, CheckpointedStateScope scope)booleanFsMergingCheckpointStorageLocation. 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)voidFsMergingCheckpointStorageLocation. 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 classByteStreamStateHandleA 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 StreamStateHandleMemCheckpointStreamFactory.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 booleanMemCheckpointStreamFactory. 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)
-