Class WindowOperator.PerWindowStateStore
- java.lang.Object
-
- org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
-
- org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
-
- All Implemented Interfaces:
KeyedStateStore
public class WindowOperator.PerWindowStateStore extends WindowOperator.AbstractPerWindowStateStore
Regular per-window state store for use withProcessWindowFunction
.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
window
-
Fields inherited from class org.apache.flink.runtime.state.DefaultKeyedStateStore
keyedStateBackend, serializerFactory
-
-
Constructor Summary
Constructors Constructor Description PerWindowStateStore(KeyedStateBackend<?> keyedStateBackend, ExecutionConfig executionConfig)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected <S extends State>
SgetPartitionedState(StateDescriptor<S,?> stateDescriptor)
-
Methods inherited from class org.apache.flink.runtime.state.DefaultKeyedStateStore
getAggregatingState, getListState, getMapState, getReducingState, getState
-
-
-
-
Constructor Detail
-
PerWindowStateStore
public PerWindowStateStore(KeyedStateBackend<?> keyedStateBackend, ExecutionConfig executionConfig)
-
-
Method Detail
-
getPartitionedState
protected <S extends State> S getPartitionedState(StateDescriptor<S,?> stateDescriptor) throws Exception
- Overrides:
getPartitionedState
in classDefaultKeyedStateStore
- Throws:
Exception
-
-