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.
|
Constructor and Description |
---|
CheckpointStatsTracker(int numRememberedCheckpoints,
List<ExecutionJobVertex> jobVertices,
CheckpointCoordinatorConfiguration jobCheckpointingConfiguration,
MetricGroup metricGroup)
Creates a new checkpoint stats tracker.
|
Modifier and Type | Method and Description |
---|---|
CheckpointCoordinatorConfiguration |
AccessExecutionGraph.getCheckpointCoordinatorConfiguration()
Returns the
CheckpointCoordinatorConfiguration or null if
checkpointing is disabled. |
CheckpointCoordinatorConfiguration |
ExecutionGraph.getCheckpointCoordinatorConfiguration() |
CheckpointCoordinatorConfiguration |
ArchivedExecutionGraph.getCheckpointCoordinatorConfiguration() |
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) |
Modifier and Type | Method and Description |
---|---|
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–2019 The Apache Software Foundation. All rights reserved.