Uses of Interface
org.apache.storm.trident.operation.Aggregator
Packages that use Aggregator
Package
Description
-
Uses of Aggregator in org.apache.storm.trident
Methods 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 everywindowCount
of 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 ofslidingInterval
and 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 everywindowCount
of 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.fluent
Methods 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.operation
Classes in org.apache.storm.trident.operation that implement Aggregator -
Uses of Aggregator in org.apache.storm.trident.operation.builtin
Classes in org.apache.storm.trident.operation.builtin that implement AggregatorModifier and TypeClassDescriptionclass
AbstractAggregator
for comparing two values in a stream.static class
static class
class
This aggregator computes the maximum of aggregated tuples in a stream.class
This aggregator computes the maximum of aggregated tuples in a stream.class
This aggregator computes the minimum of aggregated tuples in a stream.class
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 AggregatorModifier and TypeClassDescriptionclass
class
class
class
class
Constructors 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.processor
Constructors in org.apache.storm.trident.planner.processor with parameters of type Aggregator -
Uses of Aggregator in org.apache.storm.trident.testing
Classes in org.apache.storm.trident.testing that implement Aggregator -
Uses of Aggregator in org.apache.storm.trident.windowing
Fields in org.apache.storm.trident.windowing declared as AggregatorModifier and TypeFieldDescriptionprotected final Aggregator
AbstractTridentWindowManager.aggregator
Constructors 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)