Modifier and Type | Method and Description |
---|---|
void |
StateAssignmentOperation.checkParallelismPreconditions(List<OperatorState> operatorStates,
ExecutionJobVertex executionJobVertex) |
Modifier and Type | Method and Description |
---|---|
static CompletedCheckpoint |
Checkpoints.loadAndValidateCheckpoint(JobID jobId,
Map<JobVertexID,ExecutionJobVertex> tasks,
CompletedCheckpointStorageLocation location,
ClassLoader classLoader,
boolean allowNonRestoredState) |
boolean |
CheckpointCoordinator.restoreInitialCheckpointIfPresent(Set<ExecutionJobVertex> tasks)
Restores the latest checkpointed at the beginning of the job execution.
|
boolean |
CheckpointCoordinator.restoreLatestCheckpointedState(Map<JobVertexID,ExecutionJobVertex> tasks,
boolean errorIfNoCheckpoint,
boolean allowNonRestoredState)
Deprecated.
|
boolean |
CheckpointCoordinator.restoreLatestCheckpointedStateToAll(Set<ExecutionJobVertex> tasks,
boolean allowNonRestoredState)
Restores the latest checkpointed state to all tasks and all coordinators.
|
OptionalLong |
CheckpointCoordinator.restoreLatestCheckpointedStateToSubtasks(Set<ExecutionJobVertex> tasks)
Restores the latest checkpointed state to a set of subtasks.
|
boolean |
CheckpointCoordinator.restoreSavepoint(String savepointPointer,
boolean allowNonRestored,
Map<JobVertexID,ExecutionJobVertex> tasks,
ClassLoader userClassLoader)
Restore the state with given savepoint.
|
Constructor and Description |
---|
CheckpointStatsTracker(int numRememberedCheckpoints,
List<ExecutionJobVertex> jobVertices,
CheckpointCoordinatorConfiguration jobCheckpointingConfiguration,
MetricGroup metricGroup)
Creates a new checkpoint stats tracker.
|
StateAssignmentOperation(long restoreCheckpointId,
Set<ExecutionJobVertex> tasks,
Map<OperatorID,OperatorState> operatorStates,
boolean allowNonRestoredState) |
Modifier and Type | Method and Description |
---|---|
ExecutionJobVertex |
ExecutionVertex.getJobVertex() |
ExecutionJobVertex |
ExecutionGraph.getJobVertex(JobVertexID id) |
ExecutionJobVertex |
IntermediateResult.getProducer() |
Modifier and Type | Method and Description |
---|---|
Map<JobVertexID,ExecutionJobVertex> |
ExecutionGraph.getAllVertices() |
Iterable<ExecutionJobVertex> |
ExecutionGraph.getVerticesTopologically() |
Constructor and Description |
---|
ArchivedExecutionJobVertex(ExecutionJobVertex jobVertex) |
ExecutionVertex(ExecutionJobVertex jobVertex,
int subTaskIndex,
IntermediateResult[] producedDataSets,
Time timeout,
long initialGlobalModVersion,
long createTimestamp,
int maxPriorExecutionHistoryLength)
Creates an ExecutionVertex.
|
IntermediateResult(IntermediateDataSetID id,
ExecutionJobVertex producer,
int numParallelProducers,
ResultPartitionType resultType) |
Modifier and Type | Method and Description |
---|---|
abstract void |
FailoverStrategy.notifyNewVertices(List<ExecutionJobVertex> newJobVerticesTopological)
Called whenever new vertices are added to the ExecutionGraph.
|
void |
NoOpFailoverStrategy.notifyNewVertices(List<ExecutionJobVertex> newJobVerticesTopological) |
void |
RestartAllStrategy.notifyNewVertices(List<ExecutionJobVertex> newJobVerticesTopological) |
Modifier and Type | Method and Description |
---|---|
static OperatorCoordinatorHolder |
OperatorCoordinatorHolder.create(SerializedValue<OperatorCoordinator.Provider> serializedProvider,
ExecutionJobVertex jobVertex,
ClassLoader classLoader) |
Constructor and Description |
---|
KvStateLocationRegistry(JobID jobId,
Map<JobVertexID,ExecutionJobVertex> jobVertices)
Creates the registry for the job.
|
Modifier and Type | Method and Description |
---|---|
Optional<OperatorBackPressureStats> |
BackPressureStatsTrackerImpl.getOperatorBackPressureStats(ExecutionJobVertex vertex)
Returns back pressure statistics for a operator.
|
Optional<OperatorBackPressureStats> |
BackPressureStatsTracker.getOperatorBackPressureStats(ExecutionJobVertex vertex)
Returns back pressure statistics for an operator.
|
Modifier and Type | Method and Description |
---|---|
ExecutionJobVertex |
SchedulerBase.getExecutionJobVertex(JobVertexID jobVertexId) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.