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 createStreamOperatorStateContextobjects for stream operators from theTaskStateManagerof 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 interfaceStreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R extends org.apache.flink.util.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
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected <K,R extends org.apache.flink.util.Disposable & Closeable>
RkeyedStatedBackend(org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, String operatorIdentifierText, PrioritizedOperatorSubtaskState prioritizedOperatorSubtaskStates, org.apache.flink.core.fs.CloseableRegistry backendCloseableRegistry, org.apache.flink.metrics.MetricGroup metricGroup, double managedMemoryFraction, StateObject.StateObjectSizeStatsCollector statsCollector, StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R> keyedStateBackendCreator)protected OperatorStateBackendoperatorStateBackend(String operatorIdentifierText, PrioritizedOperatorSubtaskState prioritizedOperatorSubtaskStates, org.apache.flink.core.fs.CloseableRegistry backendCloseableRegistry, StateObject.StateObjectSizeStatsCollector statsCollector)protected org.apache.flink.util.CloseableIterable<KeyGroupStatePartitionStreamProvider>rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives, StateObject.StateObjectSizeStatsCollector statsCollector)protected org.apache.flink.util.CloseableIterable<StatePartitionStreamProvider>rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>> restoreStateAlternatives, StateObject.StateObjectSizeStatsCollector statsCollector)StreamOperatorStateContextstreamOperatorStateContext(OperatorID operatorID, String operatorClassName, ProcessingTimeService processingTimeService, KeyContext keyContext, org.apache.flink.api.common.typeutils.TypeSerializer<?> keySerializer, org.apache.flink.core.fs.CloseableRegistry streamTaskCloseableRegistry, org.apache.flink.metrics.MetricGroup metricGroup, double managedMemoryFraction, boolean isUsingCustomRawKeyedState, boolean isAsyncState)Returns theStreamOperatorStateContextfor anAbstractStreamOperatorthat runs in the stream task that owns this manager.
-
-
-
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 org.apache.flink.api.common.typeutils.TypeSerializer<?> keySerializer, @Nonnull org.apache.flink.core.fs.CloseableRegistry streamTaskCloseableRegistry, @Nonnull org.apache.flink.metrics.MetricGroup metricGroup, double managedMemoryFraction, boolean isUsingCustomRawKeyedState, boolean isAsyncState) throws Exception
Description copied from interface:StreamTaskStateInitializerReturns theStreamOperatorStateContextfor anAbstractStreamOperatorthat runs in the stream task that owns this manager.- Specified by:
streamOperatorStateContextin 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 theAbstractStreamOperatoris 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, org.apache.flink.core.fs.CloseableRegistry backendCloseableRegistry, StateObject.StateObjectSizeStatsCollector statsCollector) throws Exception
- Throws:
Exception
-
keyedStatedBackend
protected <K,R extends org.apache.flink.util.Disposable & Closeable> R keyedStatedBackend(org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, String operatorIdentifierText, PrioritizedOperatorSubtaskState prioritizedOperatorSubtaskStates, org.apache.flink.core.fs.CloseableRegistry backendCloseableRegistry, org.apache.flink.metrics.MetricGroup metricGroup, double managedMemoryFraction, StateObject.StateObjectSizeStatsCollector statsCollector, StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R> keyedStateBackendCreator) throws Exception
- Throws:
Exception
-
rawOperatorStateInputs
protected org.apache.flink.util.CloseableIterable<StatePartitionStreamProvider> rawOperatorStateInputs(@Nonnull Iterator<StateObjectCollection<OperatorStateHandle>> restoreStateAlternatives, @Nonnull StateObject.StateObjectSizeStatsCollector statsCollector)
-
rawKeyedStateInputs
protected org.apache.flink.util.CloseableIterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs(@Nonnull Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives, @Nonnull StateObject.StateObjectSizeStatsCollector statsCollector)
-
-