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 |
ArchivedExecutionGraph.getCheckpointCoordinatorConfiguration() |
CheckpointCoordinatorConfiguration |
AccessExecutionGraph.getCheckpointCoordinatorConfiguration()
Returns the
CheckpointCoordinatorConfiguration or null if checkpointing
is disabled. |
CheckpointCoordinatorConfiguration |
DefaultExecutionGraph.getCheckpointCoordinatorConfiguration() |
Modifier and Type | Method and Description |
---|---|
void |
DefaultExecutionGraph.enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
StateBackend checkpointStateBackend,
CheckpointStorage checkpointStorage,
CheckpointStatsTracker statsTracker,
CheckpointsCleaner checkpointsCleaner) |
void |
ExecutionGraph.enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
StateBackend checkpointStateBackend,
CheckpointStorage checkpointStorage,
CheckpointStatsTracker statsTracker,
CheckpointsCleaner checkpointsCleaner) |
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,
String checkpointStorageName) |
Modifier and Type | Method and Description |
---|---|
CheckpointCoordinatorConfiguration |
CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder.build() |
CheckpointCoordinatorConfiguration |
JobCheckpointingSettings.getCheckpointCoordinatorConfiguration() |
Constructor and Description |
---|
JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration,
SerializedValue<StateBackend> defaultStateBackend) |
JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration,
SerializedValue<StateBackend> defaultStateBackend,
TernaryBoolean changelogStateBackendEnabled,
SerializedValue<CheckpointStorage> defaultCheckpointStorage,
SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.