public class GroupedStream extends Object implements IAggregatableStream, GlobalAggregationScheme<GroupedStream>
Constructor and Description |
---|
GroupedStream(Stream stream,
Fields groupFields) |
public GroupedStream name(String name)
public ChainedAggregatorDeclarer chainedAgg()
public Stream aggregate(Aggregator agg, Fields functionFields)
public Stream aggregate(Fields inputFields, Aggregator agg, Fields functionFields)
public Stream aggregate(CombinerAggregator agg, Fields functionFields)
public Stream aggregate(Fields inputFields, CombinerAggregator agg, Fields functionFields)
public Stream aggregate(ReducerAggregator agg, Fields functionFields)
public Stream aggregate(Fields inputFields, ReducerAggregator agg, Fields functionFields)
public TridentState persistentAggregate(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields)
public TridentState persistentAggregate(StateSpec spec, CombinerAggregator agg, Fields functionFields)
public TridentState persistentAggregate(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields)
public TridentState persistentAggregate(StateSpec spec, Fields inputFields, CombinerAggregator agg, Fields functionFields)
public TridentState persistentAggregate(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields)
public TridentState persistentAggregate(StateSpec spec, Fields inputFields, ReducerAggregator agg, Fields functionFields)
public TridentState persistentAggregate(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields)
public TridentState persistentAggregate(StateSpec spec, ReducerAggregator agg, Fields functionFields)
public Stream stateQuery(TridentState state, Fields inputFields, QueryFunction function, Fields functionFields)
public Stream stateQuery(TridentState state, QueryFunction function, Fields functionFields)
public IAggregatableStream each(Fields inputFields, Function function, Fields functionFields)
each
in interface IAggregatableStream
public IAggregatableStream partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields)
partitionAggregate
in interface IAggregatableStream
public IAggregatableStream aggPartition(GroupedStream s)
aggPartition
in interface GlobalAggregationScheme<GroupedStream>
public Stream toStream()
toStream
in interface IAggregatableStream
public Fields getOutputFields()
getOutputFields
in interface IAggregatableStream
public Fields getGroupFields()
public SingleEmitAggregator.BatchToPartition singleEmitPartitioner()
singleEmitPartitioner
in interface GlobalAggregationScheme<GroupedStream>
Copyright © 2022 The Apache Software Foundation. All rights reserved.