Modifier and Type | Method and Description |
---|---|
static Map<OperatorInstanceID,List<OperatorStateHandle>> |
StateAssignmentOperation.applyRepartitioner(OperatorID operatorID,
OperatorStateRepartitioner opStateRepartitioner,
List<OperatorStateHandle> chainOpParallelStates,
int oldParallelism,
int newParallelism) |
static List<Collection<OperatorStateHandle>> |
StateAssignmentOperation.applyRepartitioner(OperatorStateRepartitioner opStateRepartitioner,
List<OperatorStateHandle> chainOpParallelStates,
int oldParallelism,
int newParallelism)
Repartitions the given operator state using the given
OperatorStateRepartitioner with respect to the new
parallelism. |
StateObjectCollection<OperatorStateHandle> |
PrioritizedOperatorSubtaskState.getJobManagerManagedOperatorState()
Returns the managed operator state from the job manager, which represents the ground truth about what this state
should represent.
|
StateObjectCollection<OperatorStateHandle> |
PrioritizedOperatorSubtaskState.getJobManagerRawOperatorState()
Returns the raw operator state from the job manager, which represents the ground truth about what this state
should represent.
|
StateObjectCollection<OperatorStateHandle> |
OperatorSubtaskState.getManagedOperatorState()
Returns a handle to the managed operator state.
|
ChainedStateHandle<OperatorStateHandle> |
SubtaskState.getManagedOperatorState() |
List<StateObjectCollection<OperatorStateHandle>> |
PrioritizedOperatorSubtaskState.getPrioritizedManagedOperatorState()
Returns an immutable list with all alternative snapshots to restore the managed operator state, in the order in
which we should attempt to restore.
|
List<StateObjectCollection<OperatorStateHandle>> |
PrioritizedOperatorSubtaskState.getPrioritizedRawOperatorState()
Returns an immutable list with all alternative snapshots to restore the raw operator state, in the order in
which we should attempt to restore.
|
StateObjectCollection<OperatorStateHandle> |
OperatorSubtaskState.getRawOperatorState()
Returns a handle to the raw operator state.
|
ChainedStateHandle<OperatorStateHandle> |
SubtaskState.getRawOperatorState() |
List<Collection<OperatorStateHandle>> |
RoundRobinOperatorStateRepartitioner.repartitionState(List<OperatorStateHandle> previousParallelSubtaskStates,
int newParallelism) |
List<Collection<OperatorStateHandle>> |
OperatorStateRepartitioner.repartitionState(List<OperatorStateHandle> previousParallelSubtaskStates,
int newParallelism) |
Modifier and Type | Method and Description |
---|---|
static Map<OperatorInstanceID,List<OperatorStateHandle>> |
StateAssignmentOperation.applyRepartitioner(OperatorID operatorID,
OperatorStateRepartitioner opStateRepartitioner,
List<OperatorStateHandle> chainOpParallelStates,
int oldParallelism,
int newParallelism) |
static List<Collection<OperatorStateHandle>> |
StateAssignmentOperation.applyRepartitioner(OperatorStateRepartitioner opStateRepartitioner,
List<OperatorStateHandle> chainOpParallelStates,
int oldParallelism,
int newParallelism)
Repartitions the given operator state using the given
OperatorStateRepartitioner with respect to the new
parallelism. |
static OperatorSubtaskState |
StateAssignmentOperation.operatorSubtaskStateFrom(OperatorInstanceID instanceID,
Map<OperatorInstanceID,List<OperatorStateHandle>> subManagedOperatorState,
Map<OperatorInstanceID,List<OperatorStateHandle>> subRawOperatorState,
Map<OperatorInstanceID,List<KeyedStateHandle>> subManagedKeyedState,
Map<OperatorInstanceID,List<KeyedStateHandle>> subRawKeyedState) |
static OperatorSubtaskState |
StateAssignmentOperation.operatorSubtaskStateFrom(OperatorInstanceID instanceID,
Map<OperatorInstanceID,List<OperatorStateHandle>> subManagedOperatorState,
Map<OperatorInstanceID,List<OperatorStateHandle>> subRawOperatorState,
Map<OperatorInstanceID,List<KeyedStateHandle>> subManagedKeyedState,
Map<OperatorInstanceID,List<KeyedStateHandle>> subRawKeyedState) |
List<Collection<OperatorStateHandle>> |
RoundRobinOperatorStateRepartitioner.repartitionState(List<OperatorStateHandle> previousParallelSubtaskStates,
int newParallelism) |
List<Collection<OperatorStateHandle>> |
OperatorStateRepartitioner.repartitionState(List<OperatorStateHandle> previousParallelSubtaskStates,
int newParallelism) |
Constructor and Description |
---|
OperatorSubtaskState(OperatorStateHandle managedOperatorState,
OperatorStateHandle rawOperatorState,
KeyedStateHandle managedKeyedState,
KeyedStateHandle rawKeyedState)
For convenience because the size of the collections is typically 0 or 1.
|
Modifier and Type | Method and Description |
---|---|
static OperatorStateHandle |
SavepointV1Serializer.deserializeOperatorStateHandle(DataInputStream dis) |
Modifier and Type | Method and Description |
---|---|
static void |
SavepointV1Serializer.serializeOperatorStateHandle(OperatorStateHandle stateHandle,
DataOutputStream dos) |
Modifier and Type | Class and Description |
---|---|
class |
OperatorStreamStateHandle
State handle for partitionable operator state.
|
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
StateSnapshotContextSynchronousImpl.getOperatorStateStreamFuture() |
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
DefaultOperatorStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultOperatorStateBackend.restore(Collection<OperatorStateHandle> restoreSnapshots) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
OperatorSnapshotFutures.getOperatorStateManagedFuture() |
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
OperatorSnapshotFutures.getOperatorStateRawFuture() |
Modifier and Type | Method and Description |
---|---|
protected CloseableIterable<StatePartitionStreamProvider> |
StreamTaskStateInitializerImpl.rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>> restoreStateAlternatives) |
void |
OperatorSnapshotFutures.setOperatorStateManagedFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture) |
void |
OperatorSnapshotFutures.setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture) |
Constructor and Description |
---|
OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture,
RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture,
RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture,
RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture) |
OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture,
RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture,
RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture,
RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.