Package | Description |
---|---|
org.apache.flink.api.common.functions | |
org.apache.flink.api.common.state | |
org.apache.flink.api.java.typeutils | |
org.apache.flink.contrib.streaming.state | |
org.apache.flink.runtime.state.heap |
This package contains the classes for key/value state backends that store the state
on the JVM heap as objects.
|
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.api.functions.windowing | |
org.apache.flink.streaming.runtime.operators.windowing.functions |
Modifier and Type | Class and Description |
---|---|
class |
RichAggregateFunction<IN,ACC,OUT>
Rich variant of the
AggregateFunction . |
Modifier and Type | Method and Description |
---|---|
AggregateFunction<IN,ACC,OUT> |
AggregatingStateDescriptor.getAggregateFunction()
Returns the aggregate function to be used for the state.
|
Constructor and Description |
---|
AggregatingStateDescriptor(String name,
AggregateFunction<IN,ACC,OUT> aggFunction,
Class<ACC> stateType)
Creates a new state descriptor with the given name, function, and type.
|
AggregatingStateDescriptor(String name,
AggregateFunction<IN,ACC,OUT> aggFunction,
TypeInformation<ACC> stateType)
Creates a new
ReducingStateDescriptor with the given name and default value. |
AggregatingStateDescriptor(String name,
AggregateFunction<IN,ACC,OUT> aggFunction,
TypeSerializer<ACC> typeSerializer)
Creates a new
ValueStateDescriptor with the given name and default value. |
Modifier and Type | Method and Description |
---|---|
static <IN,ACC> TypeInformation<ACC> |
TypeExtractor.getAggregateFunctionAccumulatorType(AggregateFunction<IN,ACC,?> function,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getAggregateFunctionReturnType(AggregateFunction<IN,?,OUT> function,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
Constructor and Description |
---|
RocksDBAggregatingState(org.rocksdb.ColumnFamilyHandle columnFamily,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<ACC> valueSerializer,
ACC defaultValue,
AggregateFunction<T,ACC,R> aggFunction,
RocksDBKeyedStateBackend<K> backend)
Creates a new
RocksDBAggregatingState . |
Constructor and Description |
---|
HeapAggregatingState(StateTable<K,N,ACC> stateTable,
TypeSerializer<K> keySerializer,
TypeSerializer<ACC> valueSerializer,
TypeSerializer<N> namespaceSerializer,
ACC defaultValue,
AggregateFunction<IN,ACC,OUT> aggregateFunction)
Creates a new key/value state for the given hash map of key/value pairs.
|
Modifier and Type | Method and Description |
---|---|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given
AggregateFunction to each window. |
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given aggregation function to each window.
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given
AggregateFunction to each window. |
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given aggregation function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
AllWindowFunction<V,R,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
AllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessAllWindowFunction<V,R,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessAllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessWindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
WindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
Constructor and Description |
---|
AggregateApplyAllWindowFunction(AggregateFunction<T,ACC,V> aggFunction,
AllWindowFunction<V,R,W> windowFunction) |
AggregateApplyWindowFunction(AggregateFunction<T,ACC,V> aggFunction,
WindowFunction<V,R,K,W> windowFunction) |
Constructor and Description |
---|
InternalAggregateProcessAllWindowFunction(AggregateFunction<T,ACC,V> aggFunction,
ProcessAllWindowFunction<V,R,W> windowFunction) |
InternalAggregateProcessWindowFunction(AggregateFunction<T,ACC,V> aggFunction,
ProcessWindowFunction<V,R,K,W> windowFunction) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.