Modifier and Type | Class and Description |
---|---|
class |
FullyFinishedOperatorState
A special operator state implementation representing the operators whose instances are all
finished.
|
Modifier and Type | Method and Description |
---|---|
OperatorState |
OperatorState.copyAndDiscardInFlightData() |
OperatorState |
FullyFinishedOperatorState.copyAndDiscardInFlightData() |
Modifier and Type | Method and Description |
---|---|
Map<OperatorID,OperatorState> |
CompletedCheckpoint.getOperatorStates() |
Map<OperatorID,OperatorState> |
PendingCheckpoint.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 |
DefaultCheckpointPlan.fulfillFinishedTaskStatus(Map<OperatorID,OperatorState> operatorStates) |
void |
FinishedTaskStateProvider.fulfillFinishedTaskStatus(Map<OperatorID,OperatorState> operatorStates)
Fulfills the state for the finished subtasks and operators to indicate they are finished.
|
static <T extends StateObject> |
StateAssignmentOperation.reDistributePartitionableStates(Map<OperatorID,OperatorState> oldOperatorStates,
int newParallelism,
java.util.function.Function<OperatorSubtaskState,StateObjectCollection<T>> extractHandle,
OperatorStateRepartitioner<T> stateRepartitioner,
Map<OperatorInstanceID,List<T>> result) |
Modifier and Type | Method and Description |
---|---|
protected abstract OperatorState |
MetadataV2V3SerializerBase.deserializeOperatorState(DataInputStream dis,
MetadataV2V3SerializerBase.DeserializationContext context) |
protected OperatorState |
MetadataV2Serializer.deserializeOperatorState(DataInputStream dis,
MetadataV2V3SerializerBase.DeserializationContext context) |
protected OperatorState |
MetadataV3Serializer.deserializeOperatorState(DataInputStream dis,
MetadataV2V3SerializerBase.DeserializationContext context) |
Modifier and Type | Method and Description |
---|---|
Collection<OperatorState> |
CheckpointMetadata.getOperatorStates() |
Modifier and Type | Method and Description |
---|---|
protected abstract void |
MetadataV2V3SerializerBase.serializeOperatorState(OperatorState operatorState,
DataOutputStream dos) |
protected void |
MetadataV2Serializer.serializeOperatorState(OperatorState operatorState,
DataOutputStream dos) |
protected void |
MetadataV3Serializer.serializeOperatorState(OperatorState operatorState,
DataOutputStream dos) |
Constructor and Description |
---|
CheckpointMetadata(long checkpointId,
Collection<OperatorState> operatorStates,
Collection<MasterState> masterStates) |
CheckpointMetadata(long checkpointId,
Collection<OperatorState> operatorStates,
Collection<MasterState> masterStates,
CheckpointProperties properties) |
Constructor and Description |
---|
BroadcastStateInputFormat(OperatorState operatorState,
Configuration configuration,
StateBackend backend,
MapStateDescriptor<K,V> descriptor)
Creates an input format for reading broadcast state from an operator in a savepoint.
|
KeyedStateInputFormat(OperatorState operatorState,
StateBackend stateBackend,
Configuration configuration,
StateReaderOperator<?,K,N,OUT> operator)
Creates an input format for reading partitioned state from an operator in a savepoint.
|
ListStateInputFormat(OperatorState operatorState,
Configuration configuration,
StateBackend backend,
ListStateDescriptor<OT> descriptor)
Creates an input format for reading list state from an operator in a savepoint.
|
UnionStateInputFormat(OperatorState operatorState,
Configuration configuration,
StateBackend backend,
ListStateDescriptor<OT> descriptor)
Creates an input format for reading union state from an operator in a savepoint.
|
Modifier and Type | Method and Description |
---|---|
void |
StatePathExtractor.flatMap(OperatorState operatorState,
Collector<Path> out) |
Modifier and Type | Method and Description |
---|---|
void |
MergeOperatorStates.reduce(Iterable<OperatorState> values,
Collector<CheckpointMetadata> out) |
void |
OperatorSubtaskStateReducer.reduce(Iterable<TaggedOperatorSubtaskState> values,
Collector<OperatorState> out) |
Modifier and Type | Method and Description |
---|---|
OperatorState |
SavepointMetadataV2.getOperatorState(String uid) |
OperatorState |
SavepointMetadata.getOperatorState(String uid)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
List<OperatorState> |
SavepointMetadataV2.getExistingOperators() |
List<OperatorState> |
SavepointMetadata.getExistingOperators()
Deprecated.
|
Constructor and Description |
---|
SavepointMetadata(int maxParallelism,
Collection<MasterState> masterStates,
Collection<OperatorState> initialStates)
Deprecated.
|
SavepointMetadataV2(int maxParallelism,
Collection<MasterState> masterStates,
Collection<OperatorState> initialStates) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.