Package | Description |
---|---|
org.apache.storm.streams | |
org.apache.storm.streams.operations | |
org.apache.storm.streams.operations.aggregators | |
org.apache.storm.streams.processors |
Modifier and Type | Method and 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 given
CombinerAggregator . |
Modifier and Type | Method and 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 a
CombinerAggregator based on initial value, accumulator and combiner. |
Modifier and Type | Class and Description |
---|---|
class |
Count<T>
Computes the count of values.
|
class |
LongSum
Computes the long sum of the input values.
|
Modifier and Type | Field and Description |
---|---|
protected CombinerAggregator<V,A,R> |
MergeAggregateByKeyProcessor.aggregator |
Constructor and 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) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.