public class DefaultKeyedStateStore extends Object implements org.apache.flink.api.common.state.KeyedStateStore
RuntimeContext
.Constructor and Description |
---|
DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend,
org.apache.flink.api.common.ExecutionConfig executionConfig) |
Modifier and Type | Method and Description |
---|---|
<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) |
<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) |
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 <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–2017 The Apache Software Foundation. All rights reserved.