Uses of Interface
org.apache.storm.trident.operation.ReducerAggregator
Package
Description
-
Uses of ReducerAggregator in org.apache.storm.trident
Modifier and TypeMethodDescriptionStream.aggregate
(ReducerAggregator agg, Fields functionFields) Stream.aggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) Stream.partitionAggregate
(ReducerAggregator agg, Fields functionFields) Stream.partitionAggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, Fields inputFields, ReducerAggregator agg, Fields functionFields) -
Uses of ReducerAggregator in org.apache.storm.trident.fluent
Modifier and TypeMethodDescriptionChainedAggregatorDeclarer.aggregate
(ReducerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.aggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate
(ReducerAggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) GroupedStream.aggregate
(ReducerAggregator agg, Fields functionFields) GroupedStream.aggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate
(ReducerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate
(ReducerAggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, Fields inputFields, ReducerAggregator agg, Fields functionFields) -
Uses of ReducerAggregator in org.apache.storm.trident.operation.impl
ModifierConstructorDescription -
Uses of ReducerAggregator in org.apache.storm.trident.state
ModifierConstructorDescriptionReducerValueUpdater
(ReducerAggregator agg, List<TridentTuple> tuples) -
Uses of ReducerAggregator in org.apache.storm.trident.state.map
ModifierConstructorDescriptionMapReducerAggStateUpdater
(ReducerAggregator agg, Fields groupFields, Fields inputFields)