Package org.apache.flink.state.api
Class WindowSavepointReader<W extends org.apache.flink.streaming.api.windowing.windows.Window>
- java.lang.Object
-
- org.apache.flink.state.api.WindowSavepointReader<W>
-
- Type Parameters:
W- The type ofWindow.
@PublicEvolving public class WindowSavepointReader<W extends org.apache.flink.streaming.api.windowing.windows.Window> extends Object
This class provides entry points for reading keyed state written out using theWindowOperator.
-
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description <K,T,ACC,R>
org.apache.flink.streaming.api.datastream.DataStream<R>aggregate(String uid, org.apache.flink.api.common.functions.AggregateFunction<T,ACC,R> aggregateFunction, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<ACC> accType, org.apache.flink.api.common.typeinfo.TypeInformation<R> outputType)Reads window state generated using anAggregateFunction.<K,T,ACC,R,OUT>
org.apache.flink.streaming.api.datastream.DataStream<OUT>aggregate(String uid, org.apache.flink.api.common.functions.AggregateFunction<T,ACC,R> aggregateFunction, WindowReaderFunction<R,OUT,K,W> readerFunction, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<ACC> accType, org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outputType)Reads window state generated using anAggregateFunction.EvictingWindowSavepointReader<W>evictor()Reads from a window that uses an evictor.<K,T,OUT>
org.apache.flink.streaming.api.datastream.DataStream<OUT>process(String uid, WindowReaderFunction<T,OUT,K,W> readerFunction, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<T> stateType, org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outputType)Reads window state generated without any preaggregation such asWindowedStream#applyandWindowedStream#process.<T,K>
org.apache.flink.streaming.api.datastream.DataStream<T>reduce(String uid, org.apache.flink.api.common.functions.ReduceFunction<T> function, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<T> reduceType)Reads window state generated using aReduceFunction.<K,T,OUT>
org.apache.flink.streaming.api.datastream.DataStream<OUT>reduce(String uid, org.apache.flink.api.common.functions.ReduceFunction<T> function, WindowReaderFunction<T,OUT,K,W> readerFunction, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<T> reduceType, org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outputType)Reads window state generated using aReduceFunction.
-
-
-
Method Detail
-
evictor
public EvictingWindowSavepointReader<W> evictor()
Reads from a window that uses an evictor.
-
reduce
public <T,K> org.apache.flink.streaming.api.datastream.DataStream<T> reduce(String uid, org.apache.flink.api.common.functions.ReduceFunction<T> function, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<T> reduceType) throws IOException
Reads window state generated using aReduceFunction.- Type Parameters:
T- The type of the reduce function.K- The key type of the operator.- Parameters:
uid- The uid of the operator.function- The reduce function used to create the window.keyType- The key type of the window.reduceType- The type information of the reduce function.- Returns:
- A
DataStreamof objects read from keyed state. - Throws:
IOException- If savepoint does not contain the specified uid.
-
reduce
public <K,T,OUT> org.apache.flink.streaming.api.datastream.DataStream<OUT> reduce(String uid, org.apache.flink.api.common.functions.ReduceFunction<T> function, WindowReaderFunction<T,OUT,K,W> readerFunction, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<T> reduceType, org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outputType) throws IOException
Reads window state generated using aReduceFunction.- Type Parameters:
K- The type of the key.T- The type of the reduce function.OUT- The output type of the reduce function.- Parameters:
uid- The uid of the operator.function- The reduce function used to create the window.readerFunction- The window reader function.keyType- The key type of the window.reduceType- The type information of the reduce function.outputType- The output type of the reader function.- Returns:
- A
DataStreamof objects read from keyed state. - Throws:
IOException- If savepoint does not contain the specified uid.
-
aggregate
public <K,T,ACC,R> org.apache.flink.streaming.api.datastream.DataStream<R> aggregate(String uid, org.apache.flink.api.common.functions.AggregateFunction<T,ACC,R> aggregateFunction, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<ACC> accType, org.apache.flink.api.common.typeinfo.TypeInformation<R> outputType) throws IOException
Reads window state generated using anAggregateFunction.- Type Parameters:
K- The type of the key.T- The type of the values that are aggregated.ACC- The type of the accumulator (intermediate aggregate state).R- The type of the aggregated result.- Parameters:
uid- The uid of the operator.aggregateFunction- The aggregate function used to create the window.keyType- The key type of the window.accType- The type information of the accumulator function.outputType- The output type of the reader function.- Returns:
- A
DataStreamof objects read from keyed state. - Throws:
IOException- If savepoint does not contain the specified uid.
-
aggregate
public <K,T,ACC,R,OUT> org.apache.flink.streaming.api.datastream.DataStream<OUT> aggregate(String uid, org.apache.flink.api.common.functions.AggregateFunction<T,ACC,R> aggregateFunction, WindowReaderFunction<R,OUT,K,W> readerFunction, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<ACC> accType, org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outputType) throws IOException
Reads window state generated using anAggregateFunction.- Type Parameters:
K- The type of the key.T- The type of the values that are aggregated.ACC- The type of the accumulator (intermediate aggregate state).R- The type of the aggregated result.OUT- The output type of the reader function.- Parameters:
uid- The uid of the operator.aggregateFunction- The aggregate function used to create the window.readerFunction- The window reader function.keyType- The key type of the window.accType- The type information of the accumulator function.outputType- The output type of the reader function.- Returns:
- A
DataStreamof objects read from keyed state. - Throws:
IOException- If savepoint does not contain the specified uid.
-
process
public <K,T,OUT> org.apache.flink.streaming.api.datastream.DataStream<OUT> process(String uid, WindowReaderFunction<T,OUT,K,W> readerFunction, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType, org.apache.flink.api.common.typeinfo.TypeInformation<T> stateType, org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outputType) throws IOException
Reads window state generated without any preaggregation such asWindowedStream#applyandWindowedStream#process.- Type Parameters:
K- The type of the key.T- The type of the records stored in state.OUT- The output type of the reader function.- Parameters:
uid- The uid of the operator.readerFunction- The window reader function.keyType- The key type of the window.stateType- The type of records stored in state.outputType- The output type of the reader function.- Returns:
- A
DataStreamof objects read from keyed state. - Throws:
IOException- If the savepoint does not contain the specified uid.
-
-