Uses of Interface
org.apache.storm.trident.operation.Aggregator
Packages that use Aggregator
Package
Description
- 
Uses of Aggregator in org.apache.storm.tridentMethods in org.apache.storm.trident with parameters of type AggregatorModifier and TypeMethodDescriptionStream.aggregate(Aggregator agg, Fields functionFields) Stream.aggregate(Fields inputFields, Aggregator agg, Fields functionFields) Stream.partitionAggregate(Aggregator agg, Fields functionFields) Stream.partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields) 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 everywindowCountof tuples and slides the window afterslideCount.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 ofslidingIntervaland completes a window atwindowDuration.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 everywindowCountof tuples.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.window(WindowConfig windowConfig, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields) Returns stream of aggregated results based on the given window configuration.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.fluentMethods in org.apache.storm.trident.fluent with parameters of type AggregatorModifier and TypeMethodDescriptionChainedAggregatorDeclarer.aggregate(Aggregator agg, Fields functionFields) ChainedAggregatorDeclarer.aggregate(Fields inputFields, Aggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate(Aggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate(Fields inputFields, Aggregator agg, Fields functionFields) GroupedStream.aggregate(Aggregator agg, Fields functionFields) GroupedStream.aggregate(Fields inputFields, Aggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate(Aggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate(Aggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields) GroupedStream.partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields) IAggregatableStream.partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields) 
- 
Uses of Aggregator in org.apache.storm.trident.operationClasses in org.apache.storm.trident.operation that implement Aggregator
- 
Uses of Aggregator in org.apache.storm.trident.operation.builtinClasses in org.apache.storm.trident.operation.builtin that implement AggregatorModifier and TypeClassDescriptionclassAbstractAggregatorfor comparing two values in a stream.static classstatic classclassThis aggregator computes the maximum of aggregated tuples in a stream.classThis aggregator computes the maximum of aggregated tuples in a stream.classThis aggregator computes the minimum of aggregated tuples in a stream.classThis aggregator computes the minimum of aggregated tuples in a stream.
- 
Uses of Aggregator in org.apache.storm.trident.operation.implClasses in org.apache.storm.trident.operation.impl that implement AggregatorModifier and TypeClassDescriptionclassclassclassclassclassConstructors in org.apache.storm.trident.operation.impl with parameters of type AggregatorModifierConstructorDescriptionChainedAggregatorImpl(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.processorConstructors in org.apache.storm.trident.planner.processor with parameters of type Aggregator
- 
Uses of Aggregator in org.apache.storm.trident.testingClasses in org.apache.storm.trident.testing that implement Aggregator
- 
Uses of Aggregator in org.apache.storm.trident.windowingFields in org.apache.storm.trident.windowing declared as AggregatorModifier and TypeFieldDescriptionprotected final AggregatorAbstractTridentWindowManager.aggregatorConstructors in org.apache.storm.trident.windowing with parameters of type AggregatorModifierConstructorDescriptionAbstractTridentWindowManager(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)