public class DoublesSketchAggregatorFactory extends AggregatorFactory
| Modifier and Type | Field and Description | 
|---|---|
static Comparator<com.yahoo.sketches.quantiles.DoublesSketch> | 
COMPARATOR  | 
| Constructor and Description | 
|---|
DoublesSketchAggregatorFactory(String name,
                              String fieldName,
                              Integer k)  | 
| 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). | 
Object | 
deserialize(Object object)
A method that knows how to "deserialize" the object from whatever form it might have been put into
 in order to transfer via JSON. 
 | 
boolean | 
equals(Object o)  | 
Aggregator | 
factorize(ColumnSelectorFactory metricFactory)  | 
BufferAggregator | 
factorizeBuffered(ColumnSelectorFactory metricFactory)  | 
Object | 
finalizeComputation(Object object)
"Finalizes" the computation of an object. 
 | 
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. 
 | 
Comparator<com.yahoo.sketches.quantiles.DoublesSketch> | 
getComparator()  | 
String | 
getFieldName()  | 
int | 
getK()  | 
int | 
getMaxIntermediateSize()
Returns the maximum size that this aggregator will require in bytes for intermediate storage of results. 
 | 
AggregatorFactory | 
getMergingFactory(AggregatorFactory other)
Returns an AggregatorFactory that can be used to merge the output of aggregators from this factory and
 other factory. 
 | 
String | 
getName()  | 
List<AggregatorFactory> | 
getRequiredColumns()
Gets a list of all columns that this AggregatorFactory will scan 
 | 
String | 
getTypeName()  | 
int | 
hashCode()  | 
List<String> | 
requiredFields()  | 
String | 
toString()  | 
makeAggregateCombiner, mergeAggregatorspublic static final Comparator<com.yahoo.sketches.quantiles.DoublesSketch> COMPARATOR
public Aggregator factorize(ColumnSelectorFactory metricFactory)
factorize in class AggregatorFactorypublic BufferAggregator factorizeBuffered(ColumnSelectorFactory metricFactory)
factorizeBuffered in class AggregatorFactorypublic Object deserialize(Object object)
AggregatorFactorydeserialize in class AggregatorFactoryobject - the object to deserializepublic Comparator<com.yahoo.sketches.quantiles.DoublesSketch> getComparator()
getComparator in class AggregatorFactorypublic Object combine(Object lhs, Object rhs)
AggregatorFactoryAggregator.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 AggregatorFactorylhs - The left hand side of the combinerhs - The right hand side of the combinepublic String getName()
getName in class AggregatorFactorypublic String getFieldName()
public int getK()
public List<String> requiredFields()
requiredFields in class AggregatorFactorypublic int getMaxIntermediateSize()
AggregatorFactorygetMaxIntermediateSize in class AggregatorFactorypublic List<AggregatorFactory> getRequiredColumns()
AggregatorFactorygetRequiredColumns in class AggregatorFactorypublic AggregatorFactory getCombiningFactory()
AggregatorFactorygetCombiningFactory in class AggregatorFactorypublic AggregatorFactory getMergingFactory(AggregatorFactory other) throws AggregatorFactoryNotMergeableException
AggregatorFactorygetMergingFactory in class AggregatorFactoryAggregatorFactoryNotMergeableExceptionpublic Object finalizeComputation(Object object)
AggregatorFactoryfinalizeComputation in class AggregatorFactoryobject - the object to be finalizedpublic String getTypeName()
getTypeName in class AggregatorFactorypublic byte[] getCacheKey()
CacheableCopyright © 2011–2018. All rights reserved.