Uses of Class
org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
-
Uses of CheckpointStorageLocationReference in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return CheckpointStorageLocationReference Modifier and Type Method Description CheckpointStorageLocationReference
CheckpointOptions. getTargetLocation()
Returns the target location for the checkpoint.Methods in org.apache.flink.runtime.checkpoint with parameters of type CheckpointStorageLocationReference Modifier and Type Method Description static CheckpointOptions
CheckpointOptions. alignedNoTimeout(SnapshotType type, CheckpointStorageLocationReference location)
static CheckpointOptions
CheckpointOptions. alignedWithTimeout(SnapshotType type, CheckpointStorageLocationReference location, long alignedCheckpointTimeout)
static CheckpointOptions
CheckpointOptions. forConfig(SnapshotType checkpointType, CheckpointStorageLocationReference locationReference, boolean isExactlyOnceMode, boolean isUnalignedEnabled, long alignedCheckpointTimeout)
static CheckpointOptions
CheckpointOptions. notExactlyOnce(SnapshotType type, CheckpointStorageLocationReference location)
static CheckpointOptions
CheckpointOptions. unaligned(SnapshotType type, CheckpointStorageLocationReference location)
Constructors in org.apache.flink.runtime.checkpoint with parameters of type CheckpointStorageLocationReference Constructor Description CheckpointOptions(SnapshotType checkpointType, CheckpointStorageLocationReference targetLocation)
CheckpointOptions(SnapshotType checkpointType, CheckpointStorageLocationReference targetLocation, CheckpointOptions.AlignmentType alignmentType, long alignedCheckpointTimeout)
-
Uses of CheckpointStorageLocationReference in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return CheckpointStorageLocationReference Modifier and Type Method Description static CheckpointStorageLocationReference
CheckpointStorageLocationReference. getDefault()
CheckpointStorageLocationReference
CheckpointStorageLocation. getLocationReference()
Gets a reference to the storage location.Methods in org.apache.flink.runtime.state with parameters of type CheckpointStorageLocationReference Modifier and Type Method Description CheckpointStreamFactory
CheckpointStorageWorkerView. resolveCheckpointStorageLocation(long checkpointId, CheckpointStorageLocationReference reference)
Resolves a storage location reference into a CheckpointStreamFactory. -
Uses of CheckpointStorageLocationReference in org.apache.flink.runtime.state.filesystem
Methods in org.apache.flink.runtime.state.filesystem that return CheckpointStorageLocationReference Modifier and Type Method Description static CheckpointStorageLocationReference
AbstractFsCheckpointStorageAccess. encodePathAsReference(org.apache.flink.core.fs.Path path)
Encodes the given path as a reference in bytes.CheckpointStorageLocationReference
FsCheckpointStorageLocation. getLocationReference()
Methods in org.apache.flink.runtime.state.filesystem with parameters of type CheckpointStorageLocationReference Modifier and Type Method Description static org.apache.flink.core.fs.Path
AbstractFsCheckpointStorageAccess. decodePathFromReference(CheckpointStorageLocationReference reference)
Decodes the given reference into a path.CheckpointStreamFactory
FsCheckpointStorageAccess. resolveCheckpointStorageLocation(long checkpointId, CheckpointStorageLocationReference reference)
CheckpointStreamFactory
FsMergingCheckpointStorageAccess. resolveCheckpointStorageLocation(long checkpointId, CheckpointStorageLocationReference reference)
Constructors in org.apache.flink.runtime.state.filesystem with parameters of type CheckpointStorageLocationReference Constructor Description FsCheckpointStorageLocation(org.apache.flink.core.fs.FileSystem fileSystem, org.apache.flink.core.fs.Path checkpointDir, org.apache.flink.core.fs.Path sharedStateDir, org.apache.flink.core.fs.Path taskOwnedStateDir, CheckpointStorageLocationReference reference, int fileStateSizeThreshold, int writeBufferSize)
FsMergingCheckpointStorageLocation(FileMergingSnapshotManager.SubtaskKey subtaskKey, org.apache.flink.core.fs.FileSystem fileSystem, org.apache.flink.core.fs.Path checkpointDir, org.apache.flink.core.fs.Path sharedStateDir, org.apache.flink.core.fs.Path taskOwnedStateDir, CheckpointStorageLocationReference reference, int fileStateSizeThreshold, int writeBufferSize, FileMergingSnapshotManager fileMergingSnapshotManager, long checkpointId)
-
Uses of CheckpointStorageLocationReference in org.apache.flink.runtime.state.memory
Methods in org.apache.flink.runtime.state.memory that return CheckpointStorageLocationReference Modifier and Type Method Description CheckpointStorageLocationReference
NonPersistentMetadataCheckpointStorageLocation. getLocationReference()
CheckpointStorageLocationReference
PersistentMetadataCheckpointStorageLocation. getLocationReference()
Methods in org.apache.flink.runtime.state.memory with parameters of type CheckpointStorageLocationReference Modifier and Type Method Description CheckpointStreamFactory
MemoryBackendCheckpointStorageAccess. resolveCheckpointStorageLocation(long checkpointId, CheckpointStorageLocationReference reference)
-