Uses of Class
org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Packages that use CheckpointProperties Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.checkpoint.metadata -
-
Uses of CheckpointProperties in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return CheckpointProperties Modifier and Type Method Description static CheckpointPropertiesCheckpointProperties. forCheckpoint(CheckpointRetentionPolicy policy)Creates the checkpoint properties for a checkpoint.static CheckpointPropertiesCheckpointProperties. forSavepoint(boolean forced, org.apache.flink.core.execution.SavepointFormatType formatType)Creates the checkpoint properties for a (manually triggered) savepoint.static CheckpointPropertiesCheckpointProperties. forSyncSavepoint(boolean forced, boolean terminate, org.apache.flink.core.execution.SavepointFormatType formatType)static CheckpointPropertiesCheckpointProperties. forUnclaimedSnapshot()Creates the checkpoint properties for a snapshot restored inRecoveryClaimMode.NO_CLAIM.CheckpointPropertiesAbstractCheckpointStats. getProperties()Returns the properties of this checkpoint.CheckpointPropertiesCompletedCheckpoint. getProperties()CheckpointPropertiesRestoredCheckpointStats. getProperties()Returns the properties of the restored checkpoint.Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type CheckpointProperties Modifier and Type Method Description Optional<CheckpointProperties>CompletedCheckpoint. getRestoredProperties()Methods in org.apache.flink.runtime.checkpoint with parameters of type CheckpointProperties Modifier and Type Method Description voidCheckpointFailureManager. handleCheckpointException(PendingCheckpoint pendingCheckpoint, CheckpointProperties checkpointProperties, CheckpointException exception, ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.JobID job, PendingCheckpointStats pendingCheckpointStats, CheckpointStatsTracker statsTracker)Failures on JM: all checkpoints - go against failure counter.static CompletedCheckpointCheckpoints. loadAndValidateCheckpoint(org.apache.flink.api.common.JobID jobId, Map<JobVertexID,ExecutionJobVertex> tasks, CompletedCheckpointStorageLocation location, ClassLoader classLoader, boolean allowNonRestoredState, CheckpointProperties checkpointProperties)PendingCheckpointStatsCheckpointStatsTracker. reportPendingCheckpoint(long checkpointId, long triggerTimestamp, CheckpointProperties props, Map<JobVertexID,Integer> vertexToDop)Creates a new pending checkpoint tracker.PendingCheckpointStatsDefaultCheckpointStatsTracker. reportPendingCheckpoint(long checkpointId, long triggerTimestamp, CheckpointProperties props, Map<JobVertexID,Integer> vertexToDop)PendingCheckpointStatsNoOpCheckpointStatsTracker. reportPendingCheckpoint(long checkpointId, long triggerTimestamp, CheckpointProperties props, Map<JobVertexID,Integer> vertexToDop)voidCheckpointStatsTracker. reportRestoredCheckpoint(long checkpointID, CheckpointProperties properties, String externalPath, long stateSize)voidDefaultCheckpointStatsTracker. reportRestoredCheckpoint(long checkpointID, CheckpointProperties properties, String externalPath, long stateSize)voidNoOpCheckpointStatsTracker. reportRestoredCheckpoint(long checkpointID, CheckpointProperties properties, String externalPath, long stateSize)Constructors in org.apache.flink.runtime.checkpoint with parameters of type CheckpointProperties 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)PendingCheckpoint(org.apache.flink.api.common.JobID jobId, long checkpointId, long checkpointTimestamp, CheckpointPlan checkpointPlan, Collection<OperatorID> operatorCoordinatorsToConfirm, Collection<String> masterStateIdentifiers, CheckpointProperties props, CompletableFuture<CompletedCheckpoint> onCompletionPromise, PendingCheckpointStats pendingCheckpointStats, CompletableFuture<Void> masterTriggerCompletionPromise) -
Uses of CheckpointProperties in org.apache.flink.runtime.checkpoint.metadata
Methods in org.apache.flink.runtime.checkpoint.metadata that return CheckpointProperties Modifier and Type Method Description CheckpointPropertiesCheckpointMetadata. getCheckpointProperties()Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type CheckpointProperties Modifier and Type Method Description CheckpointMetadataCheckpointMetadata. withProperties(CheckpointProperties properties)Constructors in org.apache.flink.runtime.checkpoint.metadata with parameters of type CheckpointProperties Constructor Description CheckpointMetadata(long checkpointId, Collection<OperatorState> operatorStates, Collection<MasterState> masterStates, CheckpointProperties properties)
-