public class DoubleMinAggregatorFactory extends SimpleDoubleAggregatorFactory
expression, fieldName, macroTable, name, storeDoubleAsFloat
Constructor and Description |
---|
DoubleMinAggregatorFactory(String name,
String fieldName) |
DoubleMinAggregatorFactory(String name,
String fieldName,
String expression,
ExprMacroTable macroTable) |
Modifier and Type | Method and Description |
---|---|
Object |
combine(Object lhs,
Object rhs)
A method that knows how to combine the outputs of
Aggregator.get() produced via AggregatorFactory.factorize(io.druid.segment.ColumnSelectorFactory) or BufferAggregator.get(java.nio.ByteBuffer, int) produced via AggregatorFactory.factorizeBuffered(io.druid.segment.ColumnSelectorFactory) . |
Aggregator |
factorize(ColumnSelectorFactory metricFactory) |
BufferAggregator |
factorizeBuffered(ColumnSelectorFactory metricFactory) |
byte[] |
getCacheKey()
Get a byte array used as a cache key.
|
AggregatorFactory |
getCombiningFactory()
Returns an AggregatorFactory that can be used to combine the output of aggregators from this factory.
|
List<AggregatorFactory> |
getRequiredColumns()
Gets a list of all columns that this AggregatorFactory will scan
|
AggregateCombiner |
makeAggregateCombiner()
Creates an AggregateCombiner to fold rollup aggregation results from serveral "rows" of different indexes during
index merging.
|
String |
toString() |
deserialize, equals, finalizeComputation, getComparator, getDoubleColumnSelector, getExpression, getFieldName, getMaxIntermediateSize, getMergingFactory, getName, getTypeName, hashCode, requiredFields
mergeAggregators
public DoubleMinAggregatorFactory(String name, String fieldName, String expression, ExprMacroTable macroTable)
public Aggregator factorize(ColumnSelectorFactory metricFactory)
factorize
in class AggregatorFactory
public BufferAggregator factorizeBuffered(ColumnSelectorFactory metricFactory)
factorizeBuffered
in class AggregatorFactory
public Object combine(Object lhs, Object rhs)
AggregatorFactory
Aggregator.get()
produced via AggregatorFactory.factorize(io.druid.segment.ColumnSelectorFactory)
or BufferAggregator.get(java.nio.ByteBuffer, int)
produced via AggregatorFactory.factorizeBuffered(io.druid.segment.ColumnSelectorFactory)
. Note, even though this method is called "combine",
this method's contract *does* allow for mutation of the input objects. Thus, any use of lhs or rhs after calling
this method is highly discouraged.combine
in class AggregatorFactory
lhs
- The left hand side of the combinerhs
- The right hand side of the combinepublic AggregateCombiner makeAggregateCombiner()
AggregatorFactory
AggregatorFactory.combine(java.lang.Object, java.lang.Object)
, with the difference that it uses
ColumnValueSelector
and it's subinterfaces to get inputs and implements ColumnValueSelector
to provide output.makeAggregateCombiner
in class AggregatorFactory
AggregateCombiner
,
IndexMerger
public AggregatorFactory getCombiningFactory()
AggregatorFactory
getCombiningFactory
in class AggregatorFactory
public List<AggregatorFactory> getRequiredColumns()
AggregatorFactory
getRequiredColumns
in class AggregatorFactory
public byte[] getCacheKey()
Cacheable
Copyright © 2011–2018. All rights reserved.