Modifier and Type | Class and Description |
---|---|
class |
RichReduceFunction<T>
Rich variant of the
ReduceFunction . |
Modifier and Type | Class and Description |
---|---|
class |
ReduceOperatorBase<T,FT extends ReduceFunction<T>>
Base data flow operator for Reduce user-defined functions.
|
Modifier and Type | Method and Description |
---|---|
ReduceFunction<T> |
ReducingStateDescriptor.getReduceFunction()
Returns the reduce function to be used for the reducing state.
|
Constructor and Description |
---|
ReducingStateDescriptor(String name,
ReduceFunction<T> reduceFunction,
Class<T> typeClass)
Creates a new
ReducingStateDescriptor with the given name, type, and default value. |
ReducingStateDescriptor(String name,
ReduceFunction<T> reduceFunction,
TypeInformation<T> typeInfo)
Creates a new
ReducingStateDescriptor with the given name and default value. |
ReducingStateDescriptor(String name,
ReduceFunction<T> reduceFunction,
TypeSerializer<T> typeSerializer)
Creates a new
ValueStateDescriptor with the given name and default value. |
Modifier and Type | Method and Description |
---|---|
ReduceOperator<T> |
DataSet.reduce(ReduceFunction<T> reducer)
Applies a Reduce transformation on a non-grouped
DataSet . |
Modifier and Type | Class and Description |
---|---|
class |
SelectByMaxFunction<T extends Tuple>
Function that enables selection by maximal value of a field.
|
class |
SelectByMinFunction<T extends Tuple>
Function that enables selection by minimal value of a field.
|
Modifier and Type | Method and Description |
---|---|
protected ReduceFunction<IN> |
ReduceOperator.getFunction() |
Modifier and Type | Method and Description |
---|---|
ReduceOperator<T> |
UnsortedGrouping.reduce(ReduceFunction<T> reducer)
Applies a Reduce transformation on a grouped
DataSet . |
Constructor and Description |
---|
ReduceOperator(DataSet<IN> input,
ReduceFunction<IN> function,
String defaultName)
This is the case for a reduce-all case (in contrast to the reduce-per-group case).
|
ReduceOperator(Grouping<IN> input,
ReduceFunction<IN> function,
String defaultName) |
Constructor and Description |
---|
PlanUnwrappingReduceOperator(ReduceFunction<T> udf,
Keys.SelectorFunctionKeys<T,K> key,
String name,
TypeInformation<T> type,
TypeInformation<Tuple2<K,T>> typeInfoWithKey) |
Modifier and Type | Class and Description |
---|---|
static class |
KMeans.CentroidAccumulator
Sums and counts point coordinates.
|
Modifier and Type | Class and Description |
---|---|
static class |
PiEstimation.SumReducer
Simply sums up all long values.
|
Modifier and Type | Class and Description |
---|---|
static class |
LinearRegression.UpdateAccumulator
Accumulator all the update.
|
Modifier and Type | Class and Description |
---|---|
static class |
DegreeAnnotationFunctions.DegreeCount<K>
Combines the vertex degree count.
|
Modifier and Type | Class and Description |
---|---|
static class |
GraphUtils.AddLongValue
Add
LongValue elements. |
Modifier and Type | Method and Description |
---|---|
Class<ReduceFunction<T>> |
ReduceCombineDriver.getStubType() |
Class<ReduceFunction<T>> |
AllReduceDriver.getStubType() |
Class<ReduceFunction<T>> |
ReduceDriver.getStubType() |
Modifier and Type | Method and Description |
---|---|
void |
ReduceCombineDriver.setup(TaskContext<ReduceFunction<T>,T> context) |
void |
AllReduceDriver.setup(TaskContext<ReduceFunction<T>,T> context) |
void |
ReduceDriver.setup(TaskContext<ReduceFunction<T>,T> context) |
Constructor and Description |
---|
ReduceFacade(ReduceFunction<T> reducer,
Collector<T> outputCollector,
boolean objectReuseEnabled) |
Modifier and Type | Method and Description |
---|---|
BootstrapTransformation<T> |
WindowedOperatorTransformation.reduce(ReduceFunction<T> function)
Applies a reduce function to the window.
|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> BootstrapTransformation<T> |
WindowedOperatorTransformation.reduce(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<T,K> DataSet<T> |
EvictingWindowReader.reduce(String uid,
ReduceFunction<T> function,
TypeInformation<K> keyType,
TypeInformation<T> reduceType)
Reads window state generated using a
ReduceFunction . |
<T,K> DataSet<T> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
TypeInformation<K> keyType,
TypeInformation<T> reduceType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
EvictingWindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
<K,T,OUT> DataSet<OUT> |
WindowReader.reduce(String uid,
ReduceFunction<T> function,
WindowReaderFunction<T,OUT,K,W> readerFunction,
TypeInformation<K> keyType,
TypeInformation<T> reduceType,
TypeInformation<OUT> outputType)
Reads window state generated using a
ReduceFunction . |
Modifier and Type | Method and Description |
---|---|
static <KEY,T,W extends Window,OUT> |
WindowReaderOperator.reduce(ReduceFunction<T> function,
WindowReaderFunction<T,OUT,KEY,W> reader,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<T> inputType) |
Constructor and Description |
---|
ReduceEvictingWindowReaderFunction(WindowReaderFunction<IN,OUT,KEY,W> wrappedFunction,
ReduceFunction<IN> reduceFunction) |
Modifier and Type | Method and Description |
---|---|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Deprecated.
|
SingleOutputStreamOperator<T> |
KeyedStream.reduce(ReduceFunction<T> reducer)
Applies a reduce transformation on the grouped data stream grouped on by the given key
position.
|
SingleOutputStreamOperator<T> |
WindowedStream.reduce(ReduceFunction<T> function)
Applies a reduce function to the window.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.reduce(ReduceFunction<T> function)
Applies a reduce function to the window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregationFunction<T>
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
|
class |
ComparableAggregator<T>
An
AggregationFunction that computes values based on comparisons of Comparables . |
class |
SumAggregator<T>
An
AggregationFunction that sums up fields. |
Constructor and Description |
---|
ReduceApplyAllWindowFunction(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> windowFunction) |
ReduceApplyProcessAllWindowFunction(ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,W> windowFunction) |
ReduceApplyProcessWindowFunction(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> windowFunction) |
ReduceApplyWindowFunction(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> windowFunction) |
Constructor and Description |
---|
BatchGroupedReduceOperator(ReduceFunction<IN> reducer,
TypeSerializer<IN> serializer) |
StreamGroupedReduceOperator(ReduceFunction<IN> reducer,
TypeSerializer<IN> serializer) |
Modifier and Type | Method and Description |
---|---|
ReduceFunction<IN> |
ReduceTransformation.getReducer() |
Constructor and Description |
---|
ReduceTransformation(String name,
int parallelism,
Transformation<IN> input,
ReduceFunction<IN> reducer,
KeySelector<IN,K> keySelector,
TypeInformation<K> keyTypeInfo) |
Modifier and Type | Method and Description |
---|---|
V |
KeyMap.putOrAggregate(K key,
V value,
ReduceFunction<V> aggregator)
Inserts or aggregates a value into the hash map.
|
<R> WindowOperator<K,T,?,R,W> |
WindowOperatorBuilder.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function) |
<R> WindowOperator<K,T,?,R,W> |
WindowOperatorBuilder.reduce(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.