Uses of Class
org.apache.flink.runtime.checkpoint.StateObjectCollection
-
-
Uses of StateObjectCollection in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return StateObjectCollection Modifier and Type Method Description protected StateObjectCollection<?>
StateObjectCollectionSerializer. create(com.esotericsoftware.kryo.Kryo kryo, com.esotericsoftware.kryo.io.Input input, Class<? extends StateObjectCollection<?>> type, int size)
static <T extends StateObject>
StateObjectCollection<T>StateObjectCollection. empty()
static <T extends StateObject>
StateObjectCollection<T>StateObjectCollection. emptyIfNull(StateObjectCollection<T> collection)
StateObjectCollection<InputChannelStateHandle>
OperatorSubtaskState. getInputChannelState()
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()
StateObjectCollection<OperatorStateHandle>
OperatorSubtaskState. getManagedOperatorState()
StateObjectCollection<InputChannelStateHandle>
PrioritizedOperatorSubtaskState. getPrioritizedInputChannelState()
StateObjectCollection<ResultSubpartitionStateHandle>
PrioritizedOperatorSubtaskState. getPrioritizedResultSubpartitionState()
StateObjectCollection<KeyedStateHandle>
OperatorSubtaskState. getRawKeyedState()
StateObjectCollection<OperatorStateHandle>
OperatorSubtaskState. getRawOperatorState()
StateObjectCollection<ResultSubpartitionStateHandle>
OperatorSubtaskState. getResultSubpartitionState()
static <T extends StateObject>
StateObjectCollection<T>StateObjectCollection. singleton(T stateObject)
static <T extends StateObject>
StateObjectCollection<T>StateObjectCollection. singletonOrEmpty(T stateObject)
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type StateObjectCollection Modifier and Type Method 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.Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type StateObjectCollection Modifier and Type Method Description protected StateObjectCollection<?>
StateObjectCollectionSerializer. create(com.esotericsoftware.kryo.Kryo kryo, com.esotericsoftware.kryo.io.Input input, Class<? extends StateObjectCollection<?>> type, int size)
static <T extends StateObject>
voidStateAssignmentOperation. reDistributePartitionableStates(Map<OperatorID,OperatorState> oldOperatorStates, int newParallelism, Function<OperatorSubtaskState,StateObjectCollection<T>> extractHandle, OperatorStateRepartitioner<T> stateRepartitioner, Map<OperatorInstanceID,List<T>> result)
-
Uses of StateObjectCollection in org.apache.flink.runtime.checkpoint.metadata
-
Uses of StateObjectCollection in org.apache.flink.runtime.state
Method parameters in org.apache.flink.runtime.state with type arguments of type StateObjectCollection Modifier and Type Method Description static Stream<StreamStateHandle>
AbstractChannelStateHandle. collectUniqueDelegates(Stream<StateObjectCollection<? extends AbstractChannelStateHandle<?>>> collections)
-
Uses of StateObjectCollection in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type StateObjectCollection Modifier and Type Method Description Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>
OperatorSnapshotFutures. getInputChannelStateFuture()
Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>
OperatorSnapshotFutures. getResultSubpartitionStateFuture()
Constructor parameters in org.apache.flink.streaming.api.operators with type arguments of type StateObjectCollection Constructor Description OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture, RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture, RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture, RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture, Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>> inputChannelStateFuture, Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>> resultSubpartitionStateFuture)
-