Package | Description |
---|---|
org.apache.flink.runtime.checkpoint | |
org.apache.flink.streaming.api.operators |
Modifier and Type | Method and Description |
---|---|
static <T extends StateObject> |
StateObjectCollection.empty() |
StateObjectCollection<KeyedStateHandle> |
PrioritizedOperatorSubtaskState.getJobManagerManagedKeyedState()
Returns the managed keyed state from the job manager, which represents the ground truth about what this state
should represent.
|
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<KeyedStateHandle> |
PrioritizedOperatorSubtaskState.getJobManagerRawKeyedState()
Returns the raw keyed 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<KeyedStateHandle> |
OperatorSubtaskState.getManagedKeyedState()
Returns a handle to the managed keyed state.
|
StateObjectCollection<OperatorStateHandle> |
OperatorSubtaskState.getManagedOperatorState()
Returns a handle to the managed operator state.
|
StateObjectCollection<KeyedStateHandle> |
OperatorSubtaskState.getRawKeyedState()
Returns a handle to the raw keyed state.
|
StateObjectCollection<OperatorStateHandle> |
OperatorSubtaskState.getRawOperatorState()
Returns a handle to the raw operator state.
|
static <T extends StateObject> |
StateObjectCollection.singleton(T stateObject) |
Modifier and Type | Method and Description |
---|---|
List<StateObjectCollection<KeyedStateHandle>> |
PrioritizedOperatorSubtaskState.getPrioritizedManagedKeyedState()
Returns an immutable list with all alternative snapshots to restore the managed keyed state, in the order in
which we should attempt to restore.
|
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<KeyedStateHandle>> |
PrioritizedOperatorSubtaskState.getPrioritizedRawKeyedState()
Returns an immutable list with all alternative snapshots to restore the raw keyed 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.
|
protected <T extends StateObject> |
PrioritizedOperatorSubtaskState.Builder.resolvePrioritizedAlternatives(StateObjectCollection<T> jobManagerState,
List<StateObjectCollection<T>> alternativesByPriority,
java.util.function.BiFunction<T,T,Boolean> approveFun)
This helper method resolves the dependencies between the ground truth of the operator state obtained from the
job manager and potential alternatives for recovery, e.g.
|
Modifier and Type | Method and Description |
---|---|
protected <T extends StateObject> |
PrioritizedOperatorSubtaskState.Builder.resolvePrioritizedAlternatives(StateObjectCollection<T> jobManagerState,
List<StateObjectCollection<T>> alternativesByPriority,
java.util.function.BiFunction<T,T,Boolean> approveFun)
This helper method resolves the dependencies between the ground truth of the operator state obtained from the
job manager and potential alternatives for recovery, e.g.
|
Modifier and Type | Method and Description |
---|---|
protected <T extends StateObject> |
PrioritizedOperatorSubtaskState.Builder.resolvePrioritizedAlternatives(StateObjectCollection<T> jobManagerState,
List<StateObjectCollection<T>> alternativesByPriority,
java.util.function.BiFunction<T,T,Boolean> approveFun)
This helper method resolves the dependencies between the ground truth of the operator state obtained from the
job manager and potential alternatives for recovery, e.g.
|
Modifier and Type | Method and Description |
---|---|
protected CloseableIterable<KeyGroupStatePartitionStreamProvider> |
StreamTaskStateInitializerImpl.rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives) |
protected CloseableIterable<StatePartitionStreamProvider> |
StreamTaskStateInitializerImpl.rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>> restoreStateAlternatives) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.