Uses of Interface
org.apache.storm.streams.operations.CombinerAggregator
Package
Description
-
Uses of CombinerAggregator in org.apache.storm.streams
Modifier and TypeMethodDescription<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
Modifier and TypeMethodDescriptionstatic <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
-
Uses of CombinerAggregator in org.apache.storm.streams.processors
Modifier and TypeFieldDescriptionprotected final CombinerAggregator<V,
A, R> MergeAggregateByKeyProcessor.aggregator
ModifierConstructorDescriptionAggregateByKeyProcessor
(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)