Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
ClientMergeQuery.getAggregators() |
Constructor and Description |
---|
ClientMergeQuery(String dataSource,
List<io.druid.timeline.DataSegment> segments,
List<AggregatorFactory> aggregators) |
Modifier and Type | Method and Description |
---|---|
static io.druid.data.input.InputRow |
InputRowSerde.fromBytes(byte[] data,
AggregatorFactory[] aggs) |
protected File |
LegacyIndexGeneratorJob.LegacyIndexGeneratorReducer.mergeQueryableIndex(List<QueryableIndex> indexes,
AggregatorFactory[] aggs,
File file,
ProgressIndicator progressIndicator) |
protected File |
IndexGeneratorJob.IndexGeneratorReducer.mergeQueryableIndex(List<QueryableIndex> indexes,
AggregatorFactory[] aggs,
File file,
ProgressIndicator progressIndicator) |
static byte[] |
InputRowSerde.toBytes(io.druid.data.input.InputRow row,
AggregatorFactory[] aggs) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
MergeTask.getAggregators() |
Constructor and Description |
---|
MergeTask(String id,
String dataSource,
List<io.druid.timeline.DataSegment> segments,
List<AggregatorFactory> aggregators,
IndexSpec indexSpec) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
Druids.TimeseriesQueryBuilder.getAggregatorSpecs() |
Modifier and Type | Method and Description |
---|---|
Druids.TimeseriesQueryBuilder |
Druids.TimeseriesQueryBuilder.aggregators(List<AggregatorFactory> a) |
static byte[] |
QueryCacheHelper.computeAggregatorBytes(List<AggregatorFactory> aggregatorSpecs) |
static int |
DruidMetrics.findNumComplexAggs(List<AggregatorFactory> aggs) |
static Aggregator[] |
QueryRunnerHelper.makeAggregators(Cursor cursor,
List<AggregatorFactory> aggregatorSpecs) |
static void |
Queries.verifyAggregations(List<AggregatorFactory> aggFactories,
List<PostAggregator> postAggs) |
Modifier and Type | Class and Description |
---|---|
class |
CountAggregatorFactory |
class |
DoubleMaxAggregatorFactory |
class |
DoubleMinAggregatorFactory |
class |
DoubleSumAggregatorFactory |
class |
FilteredAggregatorFactory |
class |
HistogramAggregatorFactory |
class |
JavaScriptAggregatorFactory |
class |
LongMaxAggregatorFactory |
class |
LongMinAggregatorFactory |
class |
LongSumAggregatorFactory |
class |
MaxAggregatorFactory
This class can be removed when we dont need "max" aggregator backward compatibility
|
class |
MinAggregatorFactory
This class can be removed when we dont need "min" aggregator backward compatibility
|
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
FilteredAggregatorFactory.getAggregator() |
AggregatorFactory |
LongSumAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
LongMinAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
LongMaxAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
JavaScriptAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
HistogramAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
FilteredAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
DoubleSumAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
DoubleMinAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
DoubleMaxAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
CountAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
AggregatorFactory.getCombiningFactory()
Returns an AggregatorFactory that can be used to combine the output of aggregators from this factory.
|
Modifier and Type | Method and Description |
---|---|
static com.metamx.common.Pair<List<AggregatorFactory>,List<PostAggregator>> |
AggregatorUtil.condensedAggregators(List<AggregatorFactory> aggList,
List<PostAggregator> postAggList,
String metric) |
List<AggregatorFactory> |
LongSumAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
LongMinAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
LongMaxAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
JavaScriptAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
HistogramAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
FilteredAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
DoubleSumAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
DoubleMinAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
DoubleMaxAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
CountAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
AggregatorFactory.getRequiredColumns()
Gets a list of all columns that this AggregatorFactory will scan
|
Modifier and Type | Method and Description |
---|---|
Object |
MetricManipulationFn.manipulate(AggregatorFactory factory,
Object object) |
Modifier and Type | Method and Description |
---|---|
static com.metamx.common.Pair<List<AggregatorFactory>,List<PostAggregator>> |
AggregatorUtil.condensedAggregators(List<AggregatorFactory> aggList,
List<PostAggregator> postAggList,
String metric) |
Constructor and Description |
---|
FilteredAggregatorFactory(AggregatorFactory delegate,
DimFilter filter) |
Modifier and Type | Class and Description |
---|---|
class |
CardinalityAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
CardinalityAggregatorFactory.getCombiningFactory() |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
CardinalityAggregatorFactory.getRequiredColumns() |
Modifier and Type | Class and Description |
---|---|
class |
ApproximateHistogramAggregatorFactory |
class |
ApproximateHistogramFoldingAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
ApproximateHistogramFoldingAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
ApproximateHistogramAggregatorFactory.getCombiningFactory() |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
ApproximateHistogramAggregatorFactory.getRequiredColumns() |
Modifier and Type | Class and Description |
---|---|
class |
HyperUniquesAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
HyperUniquesAggregatorFactory.getCombiningFactory() |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
HyperUniquesAggregatorFactory.getRequiredColumns() |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
GroupByQuery.getAggregatorSpecs() |
Modifier and Type | Method and Description |
---|---|
GroupByQuery.Builder |
GroupByQuery.Builder.addAggregator(AggregatorFactory aggregator) |
Modifier and Type | Method and Description |
---|---|
GroupByQuery.Builder |
GroupByQuery.Builder.setAggregatorSpecs(List<AggregatorFactory> aggregatorSpecs) |
Constructor and Description |
---|
GroupByQuery(DataSource dataSource,
QuerySegmentSpec querySegmentSpec,
DimFilter dimFilter,
QueryGranularity granularity,
List<DimensionSpec> dimensions,
List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs,
HavingSpec havingSpec,
LimitSpec limitSpec,
Map<String,Object> context) |
Modifier and Type | Method and Description |
---|---|
com.google.common.base.Function<com.metamx.common.guava.Sequence<io.druid.data.input.Row>,com.metamx.common.guava.Sequence<io.druid.data.input.Row>> |
NoopLimitSpec.build(List<DimensionSpec> dimensions,
List<AggregatorFactory> aggs,
List<PostAggregator> postAggs) |
com.google.common.base.Function<com.metamx.common.guava.Sequence<io.druid.data.input.Row>,com.metamx.common.guava.Sequence<io.druid.data.input.Row>> |
LimitSpec.build(List<DimensionSpec> dimensions,
List<AggregatorFactory> aggs,
List<PostAggregator> postAggs) |
com.google.common.base.Function<com.metamx.common.guava.Sequence<io.druid.data.input.Row>,com.metamx.common.guava.Sequence<io.druid.data.input.Row>> |
DefaultLimitSpec.build(List<DimensionSpec> dimensions,
List<AggregatorFactory> aggs,
List<PostAggregator> postAggs) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
TimeseriesQuery.getAggregatorSpecs() |
Constructor and Description |
---|
TimeseriesBinaryFn(QueryGranularity granularity,
List<AggregatorFactory> aggregations) |
TimeseriesQuery(DataSource dataSource,
QuerySegmentSpec querySegmentSpec,
DimFilter dimFilter,
QueryGranularity granularity,
List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs,
Map<String,Object> context) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
TopNQueryBuilder.getAggregatorSpecs() |
List<AggregatorFactory> |
TopNQuery.getAggregatorSpecs() |
Modifier and Type | Method and Description |
---|---|
TopNQueryBuilder |
TopNQueryBuilder.aggregators(List<AggregatorFactory> a) |
protected static String[] |
TopNQueryQueryToolChest.extractFactoryName(List<AggregatorFactory> aggregatorFactories) |
Comparator |
TopNMetricSpec.getComparator(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
Comparator |
NumericTopNMetricSpec.getComparator(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
Comparator |
LexicographicTopNMetricSpec.getComparator(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
Comparator |
InvertedTopNMetricSpec.getComparator(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
Comparator |
AlphaNumericTopNMetricSpec.getComparator(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
TopNResultBuilder |
TopNMetricSpec.getResultBuilder(org.joda.time.DateTime timestamp,
DimensionSpec dimSpec,
int threshold,
Comparator comparator,
List<AggregatorFactory> aggFactories,
List<PostAggregator> postAggs) |
TopNResultBuilder |
NumericTopNMetricSpec.getResultBuilder(org.joda.time.DateTime timestamp,
DimensionSpec dimSpec,
int threshold,
Comparator comparator,
List<AggregatorFactory> aggFactories,
List<PostAggregator> postAggs) |
TopNResultBuilder |
LexicographicTopNMetricSpec.getResultBuilder(org.joda.time.DateTime timestamp,
DimensionSpec dimSpec,
int threshold,
Comparator comparator,
List<AggregatorFactory> aggFactories,
List<PostAggregator> postAggs) |
TopNResultBuilder |
InvertedTopNMetricSpec.getResultBuilder(org.joda.time.DateTime timestamp,
DimensionSpec dimSpec,
int threshold,
Comparator comparator,
List<AggregatorFactory> aggFactories,
List<PostAggregator> postAggs) |
protected static Aggregator[] |
BaseTopNAlgorithm.makeAggregators(Cursor cursor,
List<AggregatorFactory> aggregatorSpecs) |
protected static BufferAggregator[] |
BaseTopNAlgorithm.makeBufferAggregators(Cursor cursor,
List<AggregatorFactory> aggregatorSpecs) |
void |
TopNMetricSpec.verifyPreconditions(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
void |
NumericTopNMetricSpec.verifyPreconditions(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
void |
LexicographicTopNMetricSpec.verifyPreconditions(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
void |
InvertedTopNMetricSpec.verifyPreconditions(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
Constructor and Description |
---|
TopNBinaryFn(TopNResultMerger merger,
QueryGranularity granularity,
DimensionSpec dimSpec,
TopNMetricSpec topNMetricSpec,
int threshold,
List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
TopNLexicographicResultBuilder(org.joda.time.DateTime timestamp,
DimensionSpec dimSpec,
int threshold,
String previousStop,
Comparator comparator,
List<AggregatorFactory> aggFactories) |
TopNNumericResultBuilder(org.joda.time.DateTime timestamp,
DimensionSpec dimSpec,
String metricName,
int threshold,
Comparator comparator,
List<AggregatorFactory> aggFactories,
List<PostAggregator> postAggs) |
TopNQuery(DataSource dataSource,
DimensionSpec dimensionSpec,
TopNMetricSpec topNMetricSpec,
int threshold,
QuerySegmentSpec querySegmentSpec,
DimFilter dimFilter,
QueryGranularity granularity,
List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs,
Map<String,Object> context) |
Modifier and Type | Method and Description |
---|---|
static File |
IndexMerger.merge(List<IndexableAdapter> indexes,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec) |
static File |
IndexMaker.merge(List<IndexableAdapter> adapters,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec) |
static File |
IndexMerger.merge(List<IndexableAdapter> indexes,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
static File |
IndexMaker.merge(List<IndexableAdapter> adapters,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
static File |
IndexMerger.mergeQueryableIndex(List<QueryableIndex> indexes,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec) |
static File |
IndexMaker.mergeQueryableIndex(List<QueryableIndex> indexes,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec) |
static File |
IndexMerger.mergeQueryableIndex(List<QueryableIndex> indexes,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
static File |
IndexMaker.mergeQueryableIndex(List<QueryableIndex> indexes,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory[] |
IncrementalIndex.getMetricAggs() |
AggregatorFactory[] |
IncrementalIndexSchema.getMetrics() |
Modifier and Type | Method and Description |
---|---|
protected Integer |
OnheapIncrementalIndex.addToFacts(AggregatorFactory[] metrics,
boolean deserializeComplexMetrics,
io.druid.data.input.InputRow row,
AtomicInteger numEntries,
io.druid.segment.incremental.IncrementalIndex.TimeAndDims key,
ThreadLocal<io.druid.data.input.InputRow> rowContainer,
com.google.common.base.Supplier<io.druid.data.input.InputRow> rowSupplier) |
protected Integer |
OffheapIncrementalIndex.addToFacts(AggregatorFactory[] metrics,
boolean deserializeComplexMetrics,
io.druid.data.input.InputRow row,
AtomicInteger numEntries,
io.druid.segment.incremental.IncrementalIndex.TimeAndDims key,
ThreadLocal<io.druid.data.input.InputRow> rowContainer,
com.google.common.base.Supplier<io.druid.data.input.InputRow> rowSupplier) |
protected abstract Integer |
IncrementalIndex.addToFacts(AggregatorFactory[] metrics,
boolean deserializeComplexMetrics,
io.druid.data.input.InputRow row,
AtomicInteger numEntries,
io.druid.segment.incremental.IncrementalIndex.TimeAndDims key,
ThreadLocal<io.druid.data.input.InputRow> rowContainer,
com.google.common.base.Supplier<io.druid.data.input.InputRow> rowSupplier) |
protected Aggregator[] |
OnheapIncrementalIndex.initAggs(AggregatorFactory[] metrics,
com.google.common.base.Supplier<io.druid.data.input.InputRow> rowSupplier,
boolean deserializeComplexMetrics) |
protected BufferAggregator[] |
OffheapIncrementalIndex.initAggs(AggregatorFactory[] metrics,
com.google.common.base.Supplier<io.druid.data.input.InputRow> rowSupplier,
boolean deserializeComplexMetrics) |
protected abstract AggregatorType[] |
IncrementalIndex.initAggs(AggregatorFactory[] metrics,
com.google.common.base.Supplier<io.druid.data.input.InputRow> rowSupplier,
boolean deserializeComplexMetrics) |
static ColumnSelectorFactory |
IncrementalIndex.makeColumnSelectorFactory(AggregatorFactory agg,
com.google.common.base.Supplier<io.druid.data.input.InputRow> in,
boolean deserializeComplexMetrics) |
IncrementalIndexSchema.Builder |
IncrementalIndexSchema.Builder.withMetrics(AggregatorFactory[] metrics) |
Constructor and Description |
---|
IncrementalIndexSchema(long minTimestamp,
QueryGranularity gran,
io.druid.data.input.impl.DimensionsSpec dimensionsSpec,
AggregatorFactory[] metrics) |
OffheapIncrementalIndex(long minTimestamp,
QueryGranularity gran,
AggregatorFactory[] metrics,
StupidPool<ByteBuffer> bufferPool,
boolean deserializeComplexMetrics,
int maxTotalBufferSize) |
OnheapIncrementalIndex(long minTimestamp,
QueryGranularity gran,
AggregatorFactory[] metrics,
boolean deserializeComplexMetrics,
int maxRowCount) |
OnheapIncrementalIndex(long minTimestamp,
QueryGranularity gran,
AggregatorFactory[] metrics,
int maxRowCount) |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory[] |
DataSchema.getAggregators() |
Constructor and Description |
---|
DataSchema(String dataSource,
io.druid.data.input.impl.InputRowParser parser,
AggregatorFactory[] aggregators,
GranularitySpec granularitySpec) |
Modifier and Type | Field and Description |
---|---|
AggregatorFactory |
DruidSQLParser.AggregateContext.agg |
Modifier and Type | Field and Description |
---|---|
Map<String,AggregatorFactory> |
DruidSQLParser.aggregators |
Copyright © 2011–2015. All rights reserved.