Modifier and Type | Method and Description |
---|---|
CloseableIterator<StateChange> |
StateChangeFormat.read(StreamStateHandle handle,
long offset) |
Modifier and Type | Method and Description |
---|---|
Map<StateHandleID,StreamStateHandle> |
RocksDBStateUploader.uploadFilesToCheckpointFs(Map<StateHandleID,Path> files,
CheckpointStreamFactory checkpointStreamFactory,
CloseableRegistry closeableRegistry)
Upload all the files to checkpoint fileSystem using specified number of threads.
|
Modifier and Type | Method and Description |
---|---|
StreamStateHandle |
CompletedCheckpoint.getMetadataHandle() |
Modifier and Type | Method and Description |
---|---|
static StreamStateHandle |
MetadataV3Serializer.deserializeStreamStateHandle(DataInputStream dis) |
Modifier and Type | Method and Description |
---|---|
static void |
MetadataV3Serializer.serializeStreamStateHandle(StreamStateHandle stateHandle,
DataOutputStream dos) |
Modifier and Type | Class and Description |
---|---|
class |
NonClosingCheckpointOutputStream<T extends StreamStateHandle>
Abstract class to implement custom checkpoint output streams which should not be closable for
user code.
|
Modifier and Type | Interface and Description |
---|---|
interface |
OperatorStateHandle
Interface of a state handle for operator state.
|
Modifier and Type | Class and Description |
---|---|
class |
KeyGroupsSavepointStateHandle
A
KeyGroupsStateHandle 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 a
StreamStateHandle to make the referenced state object retrievable trough
a simple get call. |
Modifier and Type | Method and Description |
---|---|
StreamStateHandle |
DuplicatingCheckpointOutputStream.closeAndGetHandle() |
abstract StreamStateHandle |
CheckpointStreamFactory.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.closeAndGetPrimaryHandle()
Returns the state handle from the
DuplicatingCheckpointOutputStream.primaryOutputStream . |
StreamStateHandle |
DuplicatingCheckpointOutputStream.closeAndGetSecondaryHandle()
Returns the state handle from the
DuplicatingCheckpointOutputStream.secondaryOutputStream . |
StreamStateHandle |
AbstractChannelStateHandle.getDelegate() |
StreamStateHandle |
OperatorStreamStateHandle.getDelegateStateHandle() |
StreamStateHandle |
OperatorStateHandle.getDelegateStateHandle()
Returns the underlying stream state handle that points to the state data.
|
StreamStateHandle |
KeyGroupsStateHandle.getDelegateStateHandle() |
StreamStateHandle |
CompletedCheckpointStorageLocation.getMetadataHandle()
Gets the state handle to the checkpoint's metadata.
|
StreamStateHandle |
IncrementalLocalKeyedStateHandle.getMetaDataState() |
StreamStateHandle |
IncrementalRemoteKeyedStateHandle.getMetaStateHandle() |
StreamStateHandle |
SharedStateRegistry.Result.getReference() |
Modifier and Type | Method and Description |
---|---|
SnapshotResult<StreamStateHandle> |
CheckpointStreamWithResultProvider.closeAndFinalizeCheckpointStreamResult()
Closes the stream ans returns a snapshot result with the stream handle(s).
|
SnapshotResult<StreamStateHandle> |
CheckpointStreamWithResultProvider.PrimaryStreamOnly.closeAndFinalizeCheckpointStreamResult() |
SnapshotResult<StreamStateHandle> |
CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream.closeAndFinalizeCheckpointStreamResult() |
static Set<StreamStateHandle> |
AbstractChannelStateHandle.collectUniqueDelegates(Collection<? extends AbstractChannelStateHandle<?>>... collections) |
Map<StateHandleID,StreamStateHandle> |
IncrementalRemoteKeyedStateHandle.getPrivateState() |
Map<StateHandleID,StreamStateHandle> |
IncrementalRemoteKeyedStateHandle.getSharedState() |
Modifier and Type | Method and Description |
---|---|
KeyedStateHandle |
CheckpointStreamWithResultProvider.KeyedStateHandleFactory.create(KeyGroupRangeOffsets keyGroupRangeOffsets,
StreamStateHandle streamStateHandle) |
SharedStateRegistry.Result |
SharedStateRegistry.registerReference(SharedStateRegistryKey registrationKey,
StreamStateHandle state)
Register a reference to the given shared state in the registry.
|
Modifier and Type | Method and Description |
---|---|
static SnapshotResult<KeyedStateHandle> |
CheckpointStreamWithResultProvider.toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle> snapshotResult,
KeyGroupRangeOffsets keyGroupRangeOffsets,
CheckpointStreamWithResultProvider.KeyedStateHandleFactory stateHandleFactory)
Helper method that takes a
SnapshotResult and a KeyGroupRangeOffsets and creates a SnapshotResult by combining the
key groups offsets with all the present stream state handles. |
Constructor and Description |
---|
IncrementalRemoteKeyedStateHandle(UUID backendIdentifier,
KeyGroupRange keyGroupRange,
long checkpointId,
Map<StateHandleID,StreamStateHandle> sharedState,
Map<StateHandleID,StreamStateHandle> privateState,
StreamStateHandle metaStateHandle) |
IncrementalRemoteKeyedStateHandle(UUID backendIdentifier,
KeyGroupRange keyGroupRange,
long checkpointId,
Map<StateHandleID,StreamStateHandle> sharedState,
Map<StateHandleID,StreamStateHandle> privateState,
StreamStateHandle metaStateHandle) |
Modifier and Type | Method and Description |
---|---|
List<Tuple2<StreamStateHandle,Long>> |
ChangelogStateHandleStreamImpl.getHandlesAndOffsets() |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<StateChange> |
StateChangelogHandleStreamHandleReader.StateChangeIterator.read(StreamStateHandle handle,
long offset) |
Constructor and Description |
---|
ChangelogStateHandleStreamImpl(List<Tuple2<StreamStateHandle,Long>> handlesAndOffsets,
KeyGroupRange keyGroupRange,
long size) |
Modifier and Type | Class and Description |
---|---|
class |
FileStateHandle
StreamStateHandle for state that was written to a file stream. |
class |
RelativeFileStateHandle
A
StreamStateHandle for state that was written to a file stream. |
Modifier and Type | Method and Description |
---|---|
StreamStateHandle |
FsCheckpointStreamFactory.FsCheckpointStateOutputStream.closeAndGetHandle() |
Modifier and Type | Class and Description |
---|---|
class |
ByteStreamStateHandle
A state handle that contains stream state in a byte array.
|
Modifier and Type | Method and Description |
---|---|
StreamStateHandle |
MemCheckpointStreamFactory.MemoryCheckpointOutputStream.closeAndGetHandle() |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.