W
- The type of Window
.@PublicEvolving @Deprecated public class EvictingWindowReader<W extends Window> extends Object
WindowOperator
.Modifier and Type | Method and Description |
---|---|
<K,T,ACC,R> |
aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
TypeInformation<K> keyType,
TypeInformation<T> inputType,
TypeInformation<R> outputType)
Deprecated.
Reads window state generated using an
AggregateFunction . |
<K,T,ACC,R,OUT> |
aggregate(String uid,
AggregateFunction<T,ACC,R> aggregateFunction,
WindowReaderFunction<R,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> inputType,
TypeInformation<OUT> outputType)
Deprecated.
Reads window state generated using an
AggregateFunction . |
<K,T,OUT> DataSet<OUT> |
process(String uid,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> stateType,
TypeInformation<OUT> outputType)
Deprecated.
Reads window state generated without any preaggregation such as
WindowedStream#apply
and WindowedStream#process . |
<T,K> DataSet<T> |
reduce(String uid,
ReduceFunction<T> function,
TypeInformation<K> keyType,
TypeInformation<T> reduceType)
Deprecated.
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Deprecated.
Reads window state generated using a
ReduceFunction . |
public <T,K> DataSet<T> reduce(String uid, ReduceFunction<T> function, TypeInformation<K> keyType, TypeInformation<T> reduceType) throws IOException
ReduceFunction
.T
- The type of the reduce function.K
- The key type of the operator.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.DataSet
of objects read from keyed state.IOException
- If savepoint does not contain the specified uid.public <K,T,OUT> DataSet<OUT> reduce(String uid, ReduceFunction<T> function, WindowReaderFunction<T,OUT,K,W> readerFunction, TypeInformation<K> keyType, TypeInformation<T> reduceType, TypeInformation<OUT> outputType) throws IOException
ReduceFunction
.K
- The type of the key.T
- The type of the reduce function.OUT
- The output type of the reduce function.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.DataSet
of objects read from keyed state.IOException
- If savepoint does not contain the specified uid.public <K,T,ACC,R> DataSet<R> aggregate(String uid, AggregateFunction<T,ACC,R> aggregateFunction, TypeInformation<K> keyType, TypeInformation<T> inputType, TypeInformation<R> outputType) throws IOException
AggregateFunction
.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.uid
- The uid of the operator.aggregateFunction
- The aggregate function used to create the window.keyType
- The key type of the window.inputType
- The type information of the accumulator function.outputType
- The output type of the reader function.DataSet
of objects read from keyed state.IOException
- If savepoint does not contain the specified uid.public <K,T,ACC,R,OUT> DataSet<OUT> aggregate(String uid, AggregateFunction<T,ACC,R> aggregateFunction, WindowReaderFunction<R,OUT,K,W> readerFunction, TypeInformation<K> keyType, TypeInformation<T> inputType, TypeInformation<OUT> outputType) throws IOException
AggregateFunction
.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.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.inputType
- The type information of the accumulator function.outputType
- The output type of the reader function.DataSet
of objects read from keyed state.IOException
- If savepoint does not contain the specified uid.public <K,T,OUT> DataSet<OUT> process(String uid, WindowReaderFunction<T,OUT,K,W> readerFunction, TypeInformation<K> keyType, TypeInformation<T> stateType, TypeInformation<OUT> outputType) throws IOException
WindowedStream#apply
and WindowedStream#process
.K
- The type of the key.T
- The type of the records stored in state.OUT
- The output type of the reader function.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.DataSet
of objects read from keyed state.IOException
- If the savepoint does not contain the specified uid.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.