Package org.apache.flink.runtime.state
Class DefaultKeyedStateStore
- java.lang.Object
-
- org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- All Implemented Interfaces:
org.apache.flink.api.common.state.KeyedStateStore
- Direct Known Subclasses:
WindowOperator.AbstractPerWindowStateStore
public class DefaultKeyedStateStore extends Object implements org.apache.flink.api.common.state.KeyedStateStore
Default implementation of KeyedStateStore that currently forwards state registration to aRuntimeContext
.
-
-
Field Summary
Fields Modifier and Type Field Description protected KeyedStateBackend<?>
keyedStateBackend
protected org.apache.flink.api.common.functions.SerializerFactory
serializerFactory
-
Constructor Summary
Constructors Constructor Description DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description <IN,ACC,OUT>
org.apache.flink.api.common.state.AggregatingState<IN,OUT>getAggregatingState(org.apache.flink.api.common.state.AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)
<T> org.apache.flink.api.common.state.ListState<T>
getListState(org.apache.flink.api.common.state.ListStateDescriptor<T> stateProperties)
<UK,UV>
org.apache.flink.api.common.state.MapState<UK,UV>getMapState(org.apache.flink.api.common.state.MapStateDescriptor<UK,UV> stateProperties)
protected <S extends org.apache.flink.api.common.state.State>
SgetPartitionedState(org.apache.flink.api.common.state.StateDescriptor<S,?> stateDescriptor)
<T> org.apache.flink.api.common.state.ReducingState<T>
getReducingState(org.apache.flink.api.common.state.ReducingStateDescriptor<T> stateProperties)
<T> org.apache.flink.api.common.state.ValueState<T>
getState(org.apache.flink.api.common.state.ValueStateDescriptor<T> stateProperties)
-
-
-
Field Detail
-
keyedStateBackend
protected final KeyedStateBackend<?> keyedStateBackend
-
serializerFactory
protected final org.apache.flink.api.common.functions.SerializerFactory serializerFactory
-
-
Constructor Detail
-
DefaultKeyedStateStore
public DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)
-
-
Method Detail
-
getState
public <T> org.apache.flink.api.common.state.ValueState<T> getState(org.apache.flink.api.common.state.ValueStateDescriptor<T> stateProperties)
- Specified by:
getState
in interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getListState
public <T> org.apache.flink.api.common.state.ListState<T> getListState(org.apache.flink.api.common.state.ListStateDescriptor<T> stateProperties)
- Specified by:
getListState
in interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getReducingState
public <T> org.apache.flink.api.common.state.ReducingState<T> getReducingState(org.apache.flink.api.common.state.ReducingStateDescriptor<T> stateProperties)
- Specified by:
getReducingState
in interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getAggregatingState
public <IN,ACC,OUT> org.apache.flink.api.common.state.AggregatingState<IN,OUT> getAggregatingState(org.apache.flink.api.common.state.AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)
- Specified by:
getAggregatingState
in interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getMapState
public <UK,UV> org.apache.flink.api.common.state.MapState<UK,UV> getMapState(org.apache.flink.api.common.state.MapStateDescriptor<UK,UV> stateProperties)
- Specified by:
getMapState
in interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
-