Package | Description |
---|---|
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobgraph.tasks |
Modifier and Type | Method and Description |
---|---|
CheckpointCoordinatorConfiguration |
CheckpointStatsTracker.getJobCheckpointingConfiguration()
Returns the job's checkpointing configuration which is derived from the CheckpointConfig.
|
Modifier and Type | Method and Description |
---|---|
CheckpointCoordinatorConfiguration |
ExecutionGraph.getCheckpointCoordinatorConfiguration() |
CheckpointCoordinatorConfiguration |
ArchivedExecutionGraph.getCheckpointCoordinatorConfiguration() |
CheckpointCoordinatorConfiguration |
AccessExecutionGraph.getCheckpointCoordinatorConfiguration()
Returns the
CheckpointCoordinatorConfiguration or null if checkpointing
is disabled. |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionGraph.enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig,
List<ExecutionJobVertex> verticesToTrigger,
List<ExecutionJobVertex> verticesToWaitFor,
List<ExecutionJobVertex> verticesToCommitTo,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
StateBackend checkpointStateBackend,
CheckpointStatsTracker statsTracker) |
Constructor and Description |
---|
ArchivedExecutionGraph(JobID jobID,
String jobName,
Map<JobVertexID,ArchivedExecutionJobVertex> tasks,
List<ArchivedExecutionJobVertex> verticesInCreationOrder,
long[] stateTimestamps,
JobStatus state,
ErrorInfo failureCause,
String jsonPlan,
StringifiedAccumulatorResult[] archivedUserAccumulators,
Map<String,SerializedValue<OptionalFailure<Object>>> serializedUserAccumulators,
ArchivedExecutionConfig executionConfig,
boolean isStoppable,
CheckpointCoordinatorConfiguration jobCheckpointingConfiguration,
CheckpointStatsSnapshot checkpointStatsSnapshot,
String stateBackendName) |
Modifier and Type | Method and Description |
---|---|
CheckpointCoordinatorConfiguration |
CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder.build() |
CheckpointCoordinatorConfiguration |
JobCheckpointingSettings.getCheckpointCoordinatorConfiguration() |
Constructor and Description |
---|
JobCheckpointingSettings(List<JobVertexID> verticesToTrigger,
List<JobVertexID> verticesToAcknowledge,
List<JobVertexID> verticesToConfirm,
CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration,
SerializedValue<StateBackend> defaultStateBackend) |
JobCheckpointingSettings(List<JobVertexID> verticesToTrigger,
List<JobVertexID> verticesToAcknowledge,
List<JobVertexID> verticesToConfirm,
CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration,
SerializedValue<StateBackend> defaultStateBackend,
SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.