public class DefaultKeyedStateStore extends Object implements org.apache.flink.api.common.state.KeyedStateStore
RuntimeContext
.Modifier and Type | Field and Description |
---|---|
protected org.apache.flink.api.common.ExecutionConfig |
executionConfig |
protected KeyedStateBackend<?> |
keyedStateBackend |
Constructor and Description |
---|
DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend,
org.apache.flink.api.common.ExecutionConfig executionConfig) |
Modifier and Type | Method and Description |
---|---|
<IN,ACC,OUT> |
getAggregatingState(org.apache.flink.api.common.state.AggregatingStateDescriptor<IN,ACC,OUT> stateProperties) |
<T,ACC> org.apache.flink.api.common.state.FoldingState<T,ACC> |
getFoldingState(org.apache.flink.api.common.state.FoldingStateDescriptor<T,ACC> 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> |
getPartitionedState(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) |
protected final KeyedStateBackend<?> keyedStateBackend
protected final org.apache.flink.api.common.ExecutionConfig executionConfig
public DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.ExecutionConfig executionConfig)
public <T> org.apache.flink.api.common.state.ValueState<T> getState(org.apache.flink.api.common.state.ValueStateDescriptor<T> stateProperties)
getState
in interface org.apache.flink.api.common.state.KeyedStateStore
public <T> org.apache.flink.api.common.state.ListState<T> getListState(org.apache.flink.api.common.state.ListStateDescriptor<T> stateProperties)
getListState
in interface org.apache.flink.api.common.state.KeyedStateStore
public <T> org.apache.flink.api.common.state.ReducingState<T> getReducingState(org.apache.flink.api.common.state.ReducingStateDescriptor<T> stateProperties)
getReducingState
in interface org.apache.flink.api.common.state.KeyedStateStore
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)
getAggregatingState
in interface org.apache.flink.api.common.state.KeyedStateStore
public <T,ACC> org.apache.flink.api.common.state.FoldingState<T,ACC> getFoldingState(org.apache.flink.api.common.state.FoldingStateDescriptor<T,ACC> stateProperties)
getFoldingState
in interface org.apache.flink.api.common.state.KeyedStateStore
public <UK,UV> org.apache.flink.api.common.state.MapState<UK,UV> getMapState(org.apache.flink.api.common.state.MapStateDescriptor<UK,UV> stateProperties)
getMapState
in interface org.apache.flink.api.common.state.KeyedStateStore
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.