Class StreamTaskStateInitializerImpl
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
-
- All Implemented Interfaces:
StreamTaskStateInitializer
public class StreamTaskStateInitializerImpl extends Object implements StreamTaskStateInitializer
This class is the main implementation of aStreamTaskStateInitializer
. This class obtains the state to createStreamOperatorStateContext
objects for stream operators from theTaskStateManager
of the task that runs the stream task and hence the operator.This implementation operates on top a
TaskStateManager
, from which it receives everything required to restore state in the backends from checkpoints or savepoints.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description protected static interface
StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R extends Disposable & Closeable>
Functional interface to create the keyed state backend.
-
Constructor Summary
Constructors Constructor Description StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend)
StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend, SubTaskInitializationMetricsBuilder initializationMetrics, TtlTimeProvider ttlTimeProvider, InternalTimeServiceManager.Provider timeServiceManagerProvider, StreamTaskCancellationContext cancellationContext)
-
Method Summary
-
-
-
Constructor Detail
-
StreamTaskStateInitializerImpl
public StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend)
-
StreamTaskStateInitializerImpl
public StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend, SubTaskInitializationMetricsBuilder initializationMetrics, TtlTimeProvider ttlTimeProvider, InternalTimeServiceManager.Provider timeServiceManagerProvider, StreamTaskCancellationContext cancellationContext)
-
-
Method Detail
-
streamOperatorStateContext
public StreamOperatorStateContext streamOperatorStateContext(@Nonnull OperatorID operatorID, @Nonnull String operatorClassName, @Nonnull ProcessingTimeService processingTimeService, @Nonnull KeyContext keyContext, @Nullable TypeSerializer<?> keySerializer, @Nonnull CloseableRegistry streamTaskCloseableRegistry, @Nonnull MetricGroup metricGroup, double managedMemoryFraction, boolean isUsingCustomRawKeyedState, boolean isAsyncState) throws Exception
Description copied from interface:StreamTaskStateInitializer
Returns theStreamOperatorStateContext
for anAbstractStreamOperator
that runs in the stream task that owns this manager.- Specified by:
streamOperatorStateContext
in interfaceStreamTaskStateInitializer
- Parameters:
operatorID
- the id of the operator for which the context is created. Cannot be null.operatorClassName
- the classname of the operator instance for which the context is created. Cannot be null.keyContext
- the key context of the operator instance for which the context is created Cannot be null.keySerializer
- the key-serializer for the operator. Can be null.streamTaskCloseableRegistry
- the closeable registry to which created closeable objects will be registered.metricGroup
- the parent metric group for all statebackend metricsmanagedMemoryFraction
- the managed memory fraction of the operator for state backendisUsingCustomRawKeyedState
- flag indicating whether or not theAbstractStreamOperator
is writing custom raw keyed state.- Returns:
- a context from which the given operator can initialize everything related to state.
- Throws:
Exception
- when something went wrong while creating the context.
-
operatorStateBackend
protected OperatorStateBackend operatorStateBackend(String operatorIdentifierText, PrioritizedOperatorSubtaskState prioritizedOperatorSubtaskStates, CloseableRegistry backendCloseableRegistry, StateObject.StateObjectSizeStatsCollector statsCollector) throws Exception
- Throws:
Exception
-
keyedStatedBackend
protected <K,R extends Disposable & Closeable> R keyedStatedBackend(TypeSerializer<K> keySerializer, String operatorIdentifierText, PrioritizedOperatorSubtaskState prioritizedOperatorSubtaskStates, CloseableRegistry backendCloseableRegistry, MetricGroup metricGroup, double managedMemoryFraction, StateObject.StateObjectSizeStatsCollector statsCollector, StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R> keyedStateBackendCreator) throws Exception
- Throws:
Exception
-
rawOperatorStateInputs
protected CloseableIterable<StatePartitionStreamProvider> rawOperatorStateInputs(@Nonnull Iterator<StateObjectCollection<OperatorStateHandle>> restoreStateAlternatives, @Nonnull StateObject.StateObjectSizeStatsCollector statsCollector)
-
rawKeyedStateInputs
protected CloseableIterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs(@Nonnull Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives, @Nonnull StateObject.StateObjectSizeStatsCollector statsCollector)
-
-