Uses of Interface
org.apache.storm.trident.operation.Aggregator
-
-
Uses of Aggregator in org.apache.storm.trident
Methods in org.apache.storm.trident with parameters of type Aggregator Modifier and Type Method Description Stream
Stream. aggregate(Aggregator agg, Fields functionFields)
Stream
Stream. aggregate(Fields inputFields, Aggregator agg, Fields functionFields)
Stream
Stream. partitionAggregate(Aggregator agg, Fields functionFields)
Stream
Stream. partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields)
Stream
Stream. slidingWindow(int windowCount, int slideCount, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields)
Returns a stream of tuples which are aggregated results of a sliding window with everywindowCount
of tuples and slides the window afterslideCount
.Stream
Stream. slidingWindow(BaseWindowedBolt.Duration windowDuration, BaseWindowedBolt.Duration slidingInterval, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields)
Returns a stream of tuples which are aggregated results of a window which slides at duration ofslidingInterval
and completes a window atwindowDuration
.Stream
Stream. tumblingWindow(int windowCount, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields)
Returns a stream of tuples which are aggregated results of a tumbling window with everywindowCount
of tuples.Stream
Stream. tumblingWindow(BaseWindowedBolt.Duration windowDuration, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields)
Returns a stream of tuples which are aggregated results of a window that tumbles at duration ofwindowDuration
.Stream
Stream. window(WindowConfig windowConfig, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields)
Returns stream of aggregated results based on the given window configuration.Stream
Stream. window(WindowConfig windowConfig, Fields inputFields, Aggregator aggregator, Fields functionFields)
Returns a stream of aggregated results based on the given window configuration which uses inmemory windowing tuple store. -
Uses of Aggregator in org.apache.storm.trident.fluent
Methods in org.apache.storm.trident.fluent with parameters of type Aggregator Modifier and Type Method Description ChainedFullAggregatorDeclarer
ChainedAggregatorDeclarer. aggregate(Aggregator agg, Fields functionFields)
ChainedFullAggregatorDeclarer
ChainedAggregatorDeclarer. aggregate(Fields inputFields, Aggregator agg, Fields functionFields)
ChainedFullAggregatorDeclarer
ChainedFullAggregatorDeclarer. aggregate(Aggregator agg, Fields functionFields)
ChainedFullAggregatorDeclarer
ChainedFullAggregatorDeclarer. aggregate(Fields inputFields, Aggregator agg, Fields functionFields)
Stream
GroupedStream. aggregate(Aggregator agg, Fields functionFields)
Stream
GroupedStream. aggregate(Fields inputFields, Aggregator agg, Fields functionFields)
ChainedPartitionAggregatorDeclarer
ChainedAggregatorDeclarer. partitionAggregate(Aggregator agg, Fields functionFields)
ChainedPartitionAggregatorDeclarer
ChainedAggregatorDeclarer. partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields)
ChainedPartitionAggregatorDeclarer
ChainedPartitionAggregatorDeclarer. partitionAggregate(Aggregator agg, Fields functionFields)
ChainedPartitionAggregatorDeclarer
ChainedPartitionAggregatorDeclarer. partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields)
IAggregatableStream
GroupedStream. partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields)
IAggregatableStream
IAggregatableStream. partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields)
-
Uses of Aggregator in org.apache.storm.trident.operation
Classes in org.apache.storm.trident.operation that implement Aggregator Modifier and Type Class Description class
BaseAggregator<T>
-
Uses of Aggregator in org.apache.storm.trident.operation.builtin
Classes in org.apache.storm.trident.operation.builtin that implement Aggregator Modifier and Type Class Description class
ComparisonAggregator<T>
AbstractAggregator
for comparing two values in a stream.static class
FirstN.FirstNAgg
static class
FirstN.FirstNSortedAgg
class
Max
This aggregator computes the maximum of aggregated tuples in a stream.class
MaxWithComparator<T>
This aggregator computes the maximum of aggregated tuples in a stream.class
Min
This aggregator computes the minimum of aggregated tuples in a stream.class
MinWithComparator<T>
This aggregator computes the minimum of aggregated tuples in a stream. -
Uses of Aggregator in org.apache.storm.trident.operation.impl
Classes in org.apache.storm.trident.operation.impl that implement Aggregator Modifier and Type Class Description class
ChainedAggregatorImpl
class
CombinerAggregatorCombineImpl
class
GroupedAggregator
class
ReducerAggregatorImpl
class
SingleEmitAggregator
Constructors in org.apache.storm.trident.operation.impl with parameters of type Aggregator Constructor Description ChainedAggregatorImpl(Aggregator[] aggs, Fields[] inputFields, ComboList.Factory fact)
GroupedAggregator(Aggregator agg, Fields group, Fields input, int outSize)
SingleEmitAggregator(Aggregator agg, SingleEmitAggregator.BatchToPartition batchToPartition)
-
Uses of Aggregator in org.apache.storm.trident.planner.processor
Constructors in org.apache.storm.trident.planner.processor with parameters of type Aggregator Constructor Description AggregateProcessor(Fields inputFields, Aggregator agg)
-
Uses of Aggregator in org.apache.storm.trident.testing
Classes in org.apache.storm.trident.testing that implement Aggregator Modifier and Type Class Description class
CountAsAggregator
-
Uses of Aggregator in org.apache.storm.trident.windowing
Fields in org.apache.storm.trident.windowing declared as Aggregator Modifier and Type Field Description protected Aggregator
AbstractTridentWindowManager. aggregator
Constructors in org.apache.storm.trident.windowing with parameters of type Aggregator Constructor Description AbstractTridentWindowManager(WindowConfig windowConfig, String windowTaskId, WindowsStore windowStore, Aggregator aggregator, BatchOutputCollector delegateCollector)
InMemoryTridentWindowManager(WindowConfig windowConfig, String windowTaskId, WindowsStore windowStore, Aggregator aggregator, BatchOutputCollector delegateCollector)
StoreBasedTridentWindowManager(WindowConfig windowConfig, String windowTaskId, WindowsStore windowStore, Aggregator aggregator, BatchOutputCollector delegateCollector, Long maxTuplesCacheSize, Fields inputFields)
WindowTridentProcessor(WindowConfig windowConfig, String uniqueWindowId, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, boolean storeTuplesInStore)
-