| Modifier and Type | Method and 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(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 of  slidingIntervaland completes a window atwindowDuration. | 
| 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 every  windowCountof tuples and slides the window afterslideCount. | 
| 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 of  windowDuration. | 
| 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 every  windowCountof tuples. | 
| 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. | 
| Stream | Stream. window(WindowConfig windowConfig,
      WindowsStoreFactory windowStoreFactory,
      Fields inputFields,
      Aggregator aggregator,
      Fields functionFields)Returns stream of aggregated results based on the given window configuration. | 
| Modifier and Type | Method and Description | 
|---|---|
| ChainedFullAggregatorDeclarer | ChainedAggregatorDeclarer. aggregate(Aggregator agg,
         Fields functionFields) | 
| ChainedFullAggregatorDeclarer | ChainedFullAggregatorDeclarer. aggregate(Aggregator agg,
         Fields functionFields) | 
| Stream | GroupedStream. aggregate(Aggregator agg,
         Fields functionFields) | 
| ChainedFullAggregatorDeclarer | ChainedAggregatorDeclarer. aggregate(Fields inputFields,
         Aggregator agg,
         Fields functionFields) | 
| ChainedFullAggregatorDeclarer | ChainedFullAggregatorDeclarer. aggregate(Fields inputFields,
         Aggregator agg,
         Fields functionFields) | 
| Stream | GroupedStream. aggregate(Fields inputFields,
         Aggregator agg,
         Fields functionFields) | 
| ChainedPartitionAggregatorDeclarer | ChainedAggregatorDeclarer. partitionAggregate(Aggregator agg,
                  Fields functionFields) | 
| ChainedPartitionAggregatorDeclarer | ChainedPartitionAggregatorDeclarer. partitionAggregate(Aggregator agg,
                  Fields functionFields) | 
| IAggregatableStream | IAggregatableStream. partitionAggregate(Fields inputFields,
                  Aggregator agg,
                  Fields functionFields) | 
| ChainedPartitionAggregatorDeclarer | ChainedAggregatorDeclarer. partitionAggregate(Fields inputFields,
                  Aggregator agg,
                  Fields functionFields) | 
| ChainedPartitionAggregatorDeclarer | ChainedPartitionAggregatorDeclarer. partitionAggregate(Fields inputFields,
                  Aggregator agg,
                  Fields functionFields) | 
| IAggregatableStream | GroupedStream. partitionAggregate(Fields inputFields,
                  Aggregator agg,
                  Fields functionFields) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BaseAggregator<T> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ComparisonAggregator<T>Abstract  Aggregatorfor comparing two values in a stream. | 
| static class  | FirstN.FirstNAgg | 
| static class  | FirstN.FirstNSortedAgg | 
| class  | MaxThis 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  | MinThis aggregator computes the minimum of aggregated tuples in a stream. | 
| class  | MinWithComparator<T>This aggregator computes the minimum of aggregated tuples in a stream. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ChainedAggregatorImpl | 
| class  | CombinerAggregatorCombineImpl | 
| class  | GroupedAggregator | 
| class  | ReducerAggregatorImpl | 
| class  | SingleEmitAggregator | 
| Constructor and Description | 
|---|
| ChainedAggregatorImpl(Aggregator[] aggs,
                     Fields[] inputFields,
                     ComboList.Factory fact) | 
| GroupedAggregator(Aggregator agg,
                 Fields group,
                 Fields input,
                 int outSize) | 
| SingleEmitAggregator(Aggregator agg,
                    SingleEmitAggregator.BatchToPartition batchToPartition) | 
| Constructor and Description | 
|---|
| AggregateProcessor(Fields inputFields,
                  Aggregator agg) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CountAsAggregator | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Aggregator | AbstractTridentWindowManager. aggregator | 
| Constructor and 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) | 
Copyright © 2022 The Apache Software Foundation. All rights reserved.