Package | Description |
---|---|
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.checkpoint.savepoint | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.executiongraph.failover | |
org.apache.flink.runtime.query |
This package contains all KvState query related classes.
|
Modifier and Type | Method and Description |
---|---|
void |
StateAssignmentOperation.checkParallelismPreconditions(List<OperatorState> operatorStates,
ExecutionJobVertex executionJobVertex) |
Modifier and Type | Method and Description |
---|---|
boolean |
CheckpointCoordinator.restoreLatestCheckpointedState(Map<JobVertexID,ExecutionJobVertex> tasks,
boolean errorIfNoCheckpoint,
boolean allowNonRestoredState)
Restores the latest checkpointed state.
|
boolean |
CheckpointCoordinator.restoreSavepoint(String savepointPath,
boolean allowNonRestored,
Map<JobVertexID,ExecutionJobVertex> tasks,
ClassLoader userClassLoader)
Restore the state with given savepoint
|
Constructor and Description |
---|
CheckpointStatsTracker(int numRememberedCheckpoints,
List<ExecutionJobVertex> jobVertices,
JobCheckpointingSettings jobCheckpointingSettings,
org.apache.flink.metrics.MetricGroup metricGroup)
Creates a new checkpoint stats tracker.
|
StateAssignmentOperation(Map<JobVertexID,ExecutionJobVertex> tasks,
Map<OperatorID,OperatorState> operatorStates,
boolean allowNonRestoredState) |
Modifier and Type | Method and Description |
---|---|
static Savepoint |
SavepointV2.convertToOperatorStateSavepointV2(Map<JobVertexID,ExecutionJobVertex> tasks,
Savepoint savepoint)
Deprecated.
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
|
static CompletedCheckpoint |
SavepointLoader.loadAndValidateSavepoint(JobID jobId,
Map<JobVertexID,ExecutionJobVertex> tasks,
String savepointPath,
ClassLoader classLoader,
boolean allowNonRestoredState)
Loads a savepoint back as a
CompletedCheckpoint . |
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() |
static Map<OperatorID,ExecutionJobVertex> |
ExecutionJobVertex.includeAlternativeOperatorIDs(Map<OperatorID,ExecutionJobVertex> operatorMapping) |
static Map<JobVertexID,ExecutionJobVertex> |
ExecutionJobVertex.includeLegacyJobVertexIDs(Map<JobVertexID,ExecutionJobVertex> tasks) |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionGraph.enableCheckpointing(long interval,
long checkpointTimeout,
long minPauseBetweenCheckpoints,
int maxConcurrentCheckpoints,
ExternalizedCheckpointSettings externalizeSettings,
List<ExecutionJobVertex> verticesToTrigger,
List<ExecutionJobVertex> verticesToWaitFor,
List<ExecutionJobVertex> verticesToCommitTo,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
String checkpointDir,
StateBackend metadataStore,
CheckpointStatsTracker statsTracker) |
void |
ExecutionGraph.enableCheckpointing(long interval,
long checkpointTimeout,
long minPauseBetweenCheckpoints,
int maxConcurrentCheckpoints,
ExternalizedCheckpointSettings externalizeSettings,
List<ExecutionJobVertex> verticesToTrigger,
List<ExecutionJobVertex> verticesToWaitFor,
List<ExecutionJobVertex> verticesToCommitTo,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
String checkpointDir,
StateBackend metadataStore,
CheckpointStatsTracker statsTracker) |
void |
ExecutionGraph.enableCheckpointing(long interval,
long checkpointTimeout,
long minPauseBetweenCheckpoints,
int maxConcurrentCheckpoints,
ExternalizedCheckpointSettings externalizeSettings,
List<ExecutionJobVertex> verticesToTrigger,
List<ExecutionJobVertex> verticesToWaitFor,
List<ExecutionJobVertex> verticesToCommitTo,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
String checkpointDir,
StateBackend metadataStore,
CheckpointStatsTracker statsTracker) |
static Map<OperatorID,ExecutionJobVertex> |
ExecutionJobVertex.includeAlternativeOperatorIDs(Map<OperatorID,ExecutionJobVertex> operatorMapping) |
static Map<JobVertexID,ExecutionJobVertex> |
ExecutionJobVertex.includeLegacyJobVertexIDs(Map<JobVertexID,ExecutionJobVertex> tasks) |
Constructor and Description |
---|
ArchivedExecutionJobVertex(ExecutionJobVertex jobVertex) |
ExecutionVertex(ExecutionJobVertex jobVertex,
int subTaskIndex,
IntermediateResult[] producedDataSets,
Time timeout,
long initialGlobalModVersion,
long createTimestamp,
int maxPriorExecutionHistoryLength) |
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 |
RestartIndividualStrategy.notifyNewVertices(List<ExecutionJobVertex> newJobVerticesTopological) |
void |
RestartPipelinedRegionStrategy.notifyNewVertices(List<ExecutionJobVertex> newJobVerticesTopological) |
void |
RestartAllStrategy.notifyNewVertices(List<ExecutionJobVertex> newJobVerticesTopological) |
Constructor and Description |
---|
KvStateLocationRegistry(JobID jobId,
Map<JobVertexID,ExecutionJobVertex> jobVertices)
Creates the registry for the job.
|
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.