Uses of Interface
org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
-
-
Uses of CompletedCheckpointStorageLocation in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint with parameters of type CompletedCheckpointStorageLocation Modifier and Type Method Description static CompletedCheckpoint
Checkpoints. loadAndValidateCheckpoint(org.apache.flink.api.common.JobID jobId, Map<JobVertexID,ExecutionJobVertex> tasks, CompletedCheckpointStorageLocation location, ClassLoader classLoader, boolean allowNonRestoredState, CheckpointProperties checkpointProperties)
Constructors in org.apache.flink.runtime.checkpoint with parameters of type CompletedCheckpointStorageLocation Constructor Description CompletedCheckpoint(org.apache.flink.api.common.JobID job, long checkpointID, long timestamp, long completionTimestamp, Map<OperatorID,OperatorState> operatorStates, Collection<MasterState> masterHookStates, CheckpointProperties props, CompletedCheckpointStorageLocation storageLocation, CompletedCheckpointStats completedCheckpointStats)
CompletedCheckpoint(org.apache.flink.api.common.JobID job, long checkpointID, long timestamp, long completionTimestamp, Map<OperatorID,OperatorState> operatorStates, Collection<MasterState> masterHookStates, CheckpointProperties props, CompletedCheckpointStorageLocation storageLocation, CompletedCheckpointStats completedCheckpointStats, CheckpointProperties restoredProps)
-
Uses of CompletedCheckpointStorageLocation in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return CompletedCheckpointStorageLocation Modifier and Type Method Description abstract CompletedCheckpointStorageLocation
CheckpointMetadataOutputStream. closeAndFinalizeCheckpoint()
Closes the stream after all metadata was written and finalizes the checkpoint location.CompletedCheckpointStorageLocation
CheckpointStorage. resolveCheckpoint(String externalPointer)
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.CompletedCheckpointStorageLocation
CheckpointStorageCoordinatorView. resolveCheckpoint(String externalPointer)
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location. -
Uses of CompletedCheckpointStorageLocation in org.apache.flink.runtime.state.filesystem
Classes in org.apache.flink.runtime.state.filesystem that implement CompletedCheckpointStorageLocation Modifier and Type Class Description class
FsCompletedCheckpointStorageLocation
ACompletedCheckpointStorageLocation
that resides on a file system.Methods in org.apache.flink.runtime.state.filesystem that return CompletedCheckpointStorageLocation Modifier and Type Method Description CompletedCheckpointStorageLocation
AbstractFileStateBackend. resolveCheckpoint(String pointer)
Deprecated.CompletedCheckpointStorageLocation
AbstractFsCheckpointStorageAccess. resolveCheckpoint(String checkpointPointer)
-
Uses of CompletedCheckpointStorageLocation in org.apache.flink.runtime.state.storage
Methods in org.apache.flink.runtime.state.storage that return CompletedCheckpointStorageLocation Modifier and Type Method Description CompletedCheckpointStorageLocation
FileSystemCheckpointStorage. resolveCheckpoint(String pointer)
CompletedCheckpointStorageLocation
JobManagerCheckpointStorage. resolveCheckpoint(String pointer)
-
Uses of CompletedCheckpointStorageLocation in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state that return CompletedCheckpointStorageLocation Modifier and Type Method Description CompletedCheckpointStorageLocation
BatchExecutionCheckpointStorage. resolveCheckpoint(String externalPointer)
-