Package | Description |
---|---|
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.checkpoint.savepoint |
Modifier and Type | Method and Description |
---|---|
Map<OperatorID,OperatorState> |
PendingCheckpoint.getOperatorStates() |
Map<OperatorID,OperatorState> |
CompletedCheckpoint.getOperatorStates() |
Modifier and Type | Method and Description |
---|---|
static List<KeyedStateHandle> |
StateAssignmentOperation.getManagedKeyedStateHandles(OperatorState operatorState,
KeyGroupRange subtaskKeyGroupRange)
Collect
managedKeyedStateHandles which have intersection with given
KeyGroupRange from operatorState |
static List<KeyedStateHandle> |
StateAssignmentOperation.getRawKeyedStateHandles(OperatorState operatorState,
KeyGroupRange subtaskKeyGroupRange)
|
Modifier and Type | Method and Description |
---|---|
void |
StateAssignmentOperation.checkParallelismPreconditions(List<OperatorState> operatorStates,
ExecutionJobVertex executionJobVertex) |
Constructor and Description |
---|
CompletedCheckpoint(JobID job,
long checkpointID,
long timestamp,
long completionTimestamp,
Map<OperatorID,OperatorState> operatorStates,
Collection<MasterState> masterHookStates,
CheckpointProperties props,
CompletedCheckpointStorageLocation storageLocation) |
StateAssignmentOperation(long restoreCheckpointId,
Map<JobVertexID,ExecutionJobVertex> tasks,
Map<OperatorID,OperatorState> operatorStates,
boolean allowNonRestoredState) |
Modifier and Type | Method and Description |
---|---|
Collection<OperatorState> |
SavepointV2.getOperatorStates() |
Collection<OperatorState> |
SavepointV1.getOperatorStates() |
Collection<OperatorState> |
Savepoint.getOperatorStates()
Returns the snapshotted operator states.
|
Constructor and Description |
---|
SavepointV2(long checkpointId,
Collection<OperatorState> operatorStates,
Collection<MasterState> masterStates) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.