Uses of Interface
org.apache.storm.streams.operations.CombinerAggregator
-
Packages that use CombinerAggregator Package Description org.apache.storm.streams org.apache.storm.streams.operations org.apache.storm.streams.operations.aggregators org.apache.storm.streams.processors -
-
Uses of CombinerAggregator in org.apache.storm.streams
Methods in org.apache.storm.streams with parameters of type CombinerAggregator Modifier and Type Method Description <A,R>
Stream<R>Stream. aggregate(CombinerAggregator<? super T,A,? extends R> aggregator)
Aggregates the values in this stream using the aggregator.<A,R>
PairStream<K,R>PairStream. aggregateByKey(CombinerAggregator<? super V,A,? extends R> aggregator)
Aggregates the values for each key of this stream using the givenCombinerAggregator
. -
Uses of CombinerAggregator in org.apache.storm.streams.operations
Methods in org.apache.storm.streams.operations that return CombinerAggregator Modifier and Type Method Description static <T,R>
CombinerAggregator<T,R,R>CombinerAggregator. of(R initialValue, BiFunction<? super R,? super T,? extends R> accumulator, BiFunction<? super R,? super R,? extends R> combiner)
A static factory to create aCombinerAggregator
based on initial value, accumulator and combiner. -
Uses of CombinerAggregator in org.apache.storm.streams.operations.aggregators
Classes in org.apache.storm.streams.operations.aggregators that implement CombinerAggregator Modifier and Type Class Description class
Count<T>
Computes the count of values.class
LongSum
Computes the long sum of the input values. -
Uses of CombinerAggregator in org.apache.storm.streams.processors
Fields in org.apache.storm.streams.processors declared as CombinerAggregator Modifier and Type Field Description protected CombinerAggregator<V,A,R>
MergeAggregateByKeyProcessor. aggregator
Constructors in org.apache.storm.streams.processors with parameters of type CombinerAggregator Constructor Description AggregateByKeyProcessor(CombinerAggregator<V,A,R> aggregator)
AggregateByKeyProcessor(CombinerAggregator<V,A,R> aggregator, boolean emitAggregate)
AggregateProcessor(CombinerAggregator<T,A,R> aggregator)
AggregateProcessor(CombinerAggregator<T,A,R> aggregator, boolean emitAggregate)
MergeAggregateByKeyProcessor(CombinerAggregator<V,A,R> aggregator)
MergeAggregateProcessor(CombinerAggregator<T,A,R> aggregator)
-