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:
AsyncWindowOperator.AbstractPerWindowStateStore,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 AsyncKeyedStateBackend<?>asyncKeyedStateBackendprotected KeyedStateBackend<?>keyedStateBackendprotected org.apache.flink.api.common.functions.SerializerFactoryserializerFactoryprotected org.apache.flink.runtime.state.DefaultKeyedStateStore.SupportKeyedStateApiSetsupportKeyedStateApiSet
-
Constructor Summary
Constructors Constructor Description DefaultKeyedStateStore(AsyncKeyedStateBackend<?> asyncKeyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, AsyncKeyedStateBackend<?> asyncKeyedStateBackend, 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)<IN,ACC,OUT>
org.apache.flink.api.common.state.v2.AggregatingState<IN,OUT>getAggregatingState(org.apache.flink.api.common.state.v2.AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)<T> org.apache.flink.api.common.state.ListState<T>getListState(org.apache.flink.api.common.state.ListStateDescriptor<T> stateProperties)<T> org.apache.flink.api.common.state.v2.ListState<T>getListState(org.apache.flink.api.common.state.v2.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)<UK,UV>
org.apache.flink.api.common.state.v2.MapState<UK,UV>getMapState(org.apache.flink.api.common.state.v2.MapStateDescriptor<UK,UV> stateProperties)protected <S extends org.apache.flink.api.common.state.State>
SgetPartitionedState(org.apache.flink.api.common.state.StateDescriptor<S,?> stateDescriptor)protected <S extends org.apache.flink.api.common.state.v2.State,SV>
SgetPartitionedState(org.apache.flink.api.common.state.v2.StateDescriptor<SV> 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.v2.ReducingState<T>getReducingState(org.apache.flink.api.common.state.v2.ReducingStateDescriptor<T> stateProperties)<T> org.apache.flink.api.common.state.ValueState<T>getState(org.apache.flink.api.common.state.ValueStateDescriptor<T> stateProperties)<T> org.apache.flink.api.common.state.v2.ValueState<T>getValueState(org.apache.flink.api.common.state.v2.ValueStateDescriptor<T> stateProperties)voidsetSupportKeyedStateApiSetV2()
-
-
-
Field Detail
-
keyedStateBackend
@Nullable protected final KeyedStateBackend<?> keyedStateBackend
-
asyncKeyedStateBackend
@Nullable protected final AsyncKeyedStateBackend<?> asyncKeyedStateBackend
-
serializerFactory
protected final org.apache.flink.api.common.functions.SerializerFactory serializerFactory
-
supportKeyedStateApiSet
protected org.apache.flink.runtime.state.DefaultKeyedStateStore.SupportKeyedStateApiSet supportKeyedStateApiSet
-
-
Constructor Detail
-
DefaultKeyedStateStore
public DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)
-
DefaultKeyedStateStore
public DefaultKeyedStateStore(AsyncKeyedStateBackend<?> asyncKeyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)
-
DefaultKeyedStateStore
public DefaultKeyedStateStore(@Nullable KeyedStateBackend<?> keyedStateBackend, @Nullable AsyncKeyedStateBackend<?> asyncKeyedStateBackend, 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:
getStatein 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:
getListStatein 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:
getReducingStatein 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:
getAggregatingStatein 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:
getMapStatein interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getPartitionedState
protected <S extends org.apache.flink.api.common.state.State> S getPartitionedState(org.apache.flink.api.common.state.StateDescriptor<S,?> stateDescriptor) throws Exception- Throws:
Exception
-
getValueState
public <T> org.apache.flink.api.common.state.v2.ValueState<T> getValueState(@Nonnull org.apache.flink.api.common.state.v2.ValueStateDescriptor<T> stateProperties)- Specified by:
getValueStatein interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getListState
public <T> org.apache.flink.api.common.state.v2.ListState<T> getListState(@Nonnull org.apache.flink.api.common.state.v2.ListStateDescriptor<T> stateProperties)- Specified by:
getListStatein interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getMapState
public <UK,UV> org.apache.flink.api.common.state.v2.MapState<UK,UV> getMapState(@Nonnull org.apache.flink.api.common.state.v2.MapStateDescriptor<UK,UV> stateProperties)- Specified by:
getMapStatein interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getReducingState
public <T> org.apache.flink.api.common.state.v2.ReducingState<T> getReducingState(@Nonnull org.apache.flink.api.common.state.v2.ReducingStateDescriptor<T> stateProperties)- Specified by:
getReducingStatein interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getAggregatingState
public <IN,ACC,OUT> org.apache.flink.api.common.state.v2.AggregatingState<IN,OUT> getAggregatingState(@Nonnull org.apache.flink.api.common.state.v2.AggregatingStateDescriptor<IN,ACC,OUT> stateProperties)- Specified by:
getAggregatingStatein interfaceorg.apache.flink.api.common.state.KeyedStateStore
-
getPartitionedState
protected <S extends org.apache.flink.api.common.state.v2.State,SV> S getPartitionedState(org.apache.flink.api.common.state.v2.StateDescriptor<SV> stateDescriptor) throws Exception- Throws:
Exception
-
setSupportKeyedStateApiSetV2
public void setSupportKeyedStateApiSetV2()
-
-