public class StateInitializationContextImpl extends Object implements StateInitializationContext
StateInitializationContext
.Constructor and Description |
---|
StateInitializationContextImpl(boolean restored,
org.apache.flink.api.common.state.OperatorStateStore operatorStateStore,
org.apache.flink.api.common.state.KeyedStateStore keyedStateStore,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs,
Iterable<StatePartitionStreamProvider> rawOperatorStateInputs) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.state.KeyedStateStore |
getKeyedStateStore()
Returns an interface that allows for registering keyed state with the backend.
|
org.apache.flink.api.common.state.OperatorStateStore |
getOperatorStateStore()
Returns an interface that allows for registering operator state with the backend.
|
Iterable<KeyGroupStatePartitionStreamProvider> |
getRawKeyedStateInputs()
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to
this operator.
|
Iterable<StatePartitionStreamProvider> |
getRawOperatorStateInputs()
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to
this operator.
|
boolean |
isRestored()
Returns true, if state was restored from the snapshot of a previous execution.
|
public StateInitializationContextImpl(boolean restored, org.apache.flink.api.common.state.OperatorStateStore operatorStateStore, org.apache.flink.api.common.state.KeyedStateStore keyedStateStore, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs, Iterable<StatePartitionStreamProvider> rawOperatorStateInputs)
public boolean isRestored()
ManagedInitializationContext
isRestored
in interface ManagedInitializationContext
public Iterable<StatePartitionStreamProvider> getRawOperatorStateInputs()
StateInitializationContext
getRawOperatorStateInputs
in interface StateInitializationContext
public Iterable<KeyGroupStatePartitionStreamProvider> getRawKeyedStateInputs()
StateInitializationContext
getRawKeyedStateInputs
in interface StateInitializationContext
public org.apache.flink.api.common.state.OperatorStateStore getOperatorStateStore()
ManagedInitializationContext
getOperatorStateStore
in interface ManagedInitializationContext
public org.apache.flink.api.common.state.KeyedStateStore getKeyedStateStore()
ManagedInitializationContext
getKeyedStateStore
in interface ManagedInitializationContext
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.