Uses of Class
org.apache.flink.runtime.checkpoint.MasterState
-
Packages that use MasterState Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.checkpoint.hooks org.apache.flink.runtime.checkpoint.metadata -
-
Uses of MasterState in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type MasterState Modifier and Type Method Description Collection<MasterState>
CompletedCheckpoint. getMasterHookStates()
List<MasterState>
PendingCheckpoint. getMasterStates()
Methods in org.apache.flink.runtime.checkpoint with parameters of type MasterState Modifier and Type Method Description void
PendingCheckpoint. acknowledgeMasterState(String identifier, MasterState state)
Acknowledges a master state (state generated on the checkpoint coordinator) to the pending checkpoint.Constructor parameters in org.apache.flink.runtime.checkpoint with type arguments of type MasterState 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 MasterState in org.apache.flink.runtime.checkpoint.hooks
Methods in org.apache.flink.runtime.checkpoint.hooks that return types with arguments of type MasterState Modifier and Type Method Description static <T> CompletableFuture<MasterState>
MasterHooks. triggerHook(MasterTriggerRestoreHook<T> hook, long checkpointId, long timestamp, Executor executor)
Trigger master hook and return a completable future with state.Method parameters in org.apache.flink.runtime.checkpoint.hooks with type arguments of type MasterState Modifier and Type Method Description static void
MasterHooks. restoreMasterHooks(Map<String,MasterTriggerRestoreHook<?>> masterHooks, Collection<MasterState> states, long checkpointId, boolean allowUnmatchedState, org.slf4j.Logger log)
Calls the restore method given checkpoint master hooks and passes the given master state to them where state with a matching name is found. -
Uses of MasterState in org.apache.flink.runtime.checkpoint.metadata
Methods in org.apache.flink.runtime.checkpoint.metadata that return MasterState Modifier and Type Method Description protected MasterState
MetadataV2V3SerializerBase. deserializeMasterState(DataInputStream dis)
Methods in org.apache.flink.runtime.checkpoint.metadata that return types with arguments of type MasterState Modifier and Type Method Description Collection<MasterState>
CheckpointMetadata. getMasterStates()
Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type MasterState Modifier and Type Method Description protected void
MetadataV2V3SerializerBase. serializeMasterState(MasterState state, DataOutputStream dos)
-