Modifier and Type | Method and Description |
---|---|
AggregatorFactory[] |
BenchmarkSchemaInfo.getAggsArray() |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
BenchmarkSchemaInfo.getAggs() |
Constructor and Description |
---|
BenchmarkSchemaInfo(List<BenchmarkColumnSchema> columnSchemas,
List<AggregatorFactory> aggs,
org.joda.time.Interval dataInterval,
boolean withRollup) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
ClientMergeQuery.getAggregators() |
Constructor and Description |
---|
ClientMergeQuery(String dataSource,
List<DataSegment> segments,
List<AggregatorFactory> aggregators) |
Modifier and Type | Method and Description |
---|---|
static InputRow |
InputRowSerde.fromBytes(byte[] data,
AggregatorFactory[] aggs) |
protected File |
IndexGeneratorJob.IndexGeneratorReducer.mergeQueryableIndex(List<QueryableIndex> indexes,
AggregatorFactory[] aggs,
File file,
ProgressIndicator progressIndicator) |
static byte[] |
InputRowSerde.toBytes(InputRow row,
AggregatorFactory[] aggs,
boolean reportParseExceptions) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
MergeTask.getAggregators() |
List<AggregatorFactory> |
AppendTask.getAggregators() |
Constructor and Description |
---|
AppendTask(String id,
String dataSource,
List<DataSegment> segments,
List<AggregatorFactory> aggregators,
IndexSpec indexSpec,
Boolean buildV9Directly,
Map<String,Object> context) |
MergeTask(String id,
String dataSource,
List<DataSegment> segments,
List<AggregatorFactory> aggregators,
Boolean rollup,
IndexSpec indexSpec,
Boolean buildV9Directly,
Map<String,Object> context) |
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 List<PostAggregator> |
Queries.decoratePostAggregators(List<PostAggregator> postAggs,
Map<String,AggregatorFactory> aggFactories) |
static int |
DruidMetrics.findNumComplexAggs(List<AggregatorFactory> aggs) |
static List<PostAggregator> |
Queries.prepareAggregations(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 |
TimestampAggregatorFactory |
class |
TimestampMaxAggregatorFactory |
class |
TimestampMinAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
FilteredAggregatorFactory.getAggregator() |
AggregatorFactory |
TimestampAggregatorFactory.getCombiningFactory() |
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() |
abstract AggregatorFactory |
AggregatorFactory.getCombiningFactory()
Returns an AggregatorFactory that can be used to combine the output of aggregators from this factory.
|
AggregatorFactory |
TimestampAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
LongSumAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
LongMinAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
LongMaxAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
JavaScriptAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleSumAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleMinAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleMaxAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
AggregatorFactory.getMergingFactory(AggregatorFactory other)
Returns an AggregatorFactory that can be used to merge the output of aggregators from this factory and
other factory.
|
static AggregatorFactory[] |
AggregatorFactory.mergeAggregators(List<AggregatorFactory[]> aggregatorsList)
Merges the list of AggregatorFactory[] (presumable from metadata of some segments being merged) and
returns merged AggregatorFactory[] (for the metadata for merged segment).
|
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
TimestampAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
LongSumAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
LongMinAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
LongMaxAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
JavaScriptAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleSumAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleMinAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleMaxAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
AggregatorFactory.getMergingFactory(AggregatorFactory other)
Returns an AggregatorFactory that can be used to merge the output of aggregators from this factory and
other factory.
|
Object |
MetricManipulationFn.manipulate(AggregatorFactory factory,
Object object) |
Modifier and Type | Method and Description |
---|---|
static Pair<List<AggregatorFactory>,List<PostAggregator>> |
AggregatorUtil.condensedAggregators(List<AggregatorFactory> aggList,
List<PostAggregator> postAggList,
String metric) |
PostAggregator |
PostAggregator.decorate(Map<String,AggregatorFactory> aggregators)
Returns a richer post aggregator which are built from the given aggregators with their names and some accessible
environmental variables such as ones in the object scope.
|
Constructor and Description |
---|
AggregatorFactoryNotMergeableException(AggregatorFactory af1,
AggregatorFactory af2) |
FilteredAggregatorFactory(AggregatorFactory delegate,
DimFilter filter) |
Modifier and Type | Class and Description |
---|---|
class |
CardinalityAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
CardinalityAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
CardinalityAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
CardinalityAggregatorFactory.getRequiredColumns() |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
CardinalityAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Class and Description |
---|---|
class |
SketchAggregatorFactory |
class |
SketchMergeAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
SketchMergeAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
SketchMergeAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
SketchMergeAggregatorFactory.getRequiredColumns() |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
SketchMergeAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
PostAggregator |
SketchSetPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
PostAggregator |
SketchEstimatePostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
Modifier and Type | Class and Description |
---|---|
class |
OldSketchBuildAggregatorFactory |
class |
OldSketchMergeAggregatorFactory |
Modifier and Type | Class and Description |
---|---|
class |
DistinctCountAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
DistinctCountAggregatorFactory.getCombiningFactory() |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
DistinctCountAggregatorFactory.getRequiredColumns() |
Modifier and Type | Class and Description |
---|---|
class |
DoubleFirstAggregatorFactory |
class |
LongFirstAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
LongFirstAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
DoubleFirstAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
LongFirstAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleFirstAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
LongFirstAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
DoubleFirstAggregatorFactory.getRequiredColumns() |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
LongFirstAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleFirstAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Class and Description |
---|---|
class |
ApproximateHistogramAggregatorFactory |
class |
ApproximateHistogramFoldingAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
ApproximateHistogramFoldingAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
ApproximateHistogramAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
ApproximateHistogramAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
ApproximateHistogramAggregatorFactory.getRequiredColumns() |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
ApproximateHistogramAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
PostAggregator |
QuantilesPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
PostAggregator |
QuantilePostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
PostAggregator |
MinPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
PostAggregator |
MaxPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
PostAggregator |
EqualBucketsPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
PostAggregator |
CustomBucketsPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
PostAggregator |
BucketsPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
Modifier and Type | Class and Description |
---|---|
class |
HyperUniquesAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
HyperUniquesAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
HyperUniquesAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
HyperUniquesAggregatorFactory.getRequiredColumns() |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
HyperUniquesAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
HyperUniqueFinalizingPostAggregator |
HyperUniqueFinalizingPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
Modifier and Type | Class and Description |
---|---|
class |
DoubleLastAggregatorFactory |
class |
LongLastAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
LongLastAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
DoubleLastAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
LongLastAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleLastAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
LongLastAggregatorFactory.getRequiredColumns() |
List<AggregatorFactory> |
DoubleLastAggregatorFactory.getRequiredColumns() |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
LongLastAggregatorFactory.getMergingFactory(AggregatorFactory other) |
AggregatorFactory |
DoubleLastAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Class and Description |
---|---|
class |
VarianceAggregatorFactory |
class |
VarianceFoldingAggregatorFactory |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
VarianceAggregatorFactory.getCombiningFactory() |
AggregatorFactory |
VarianceAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
VarianceAggregatorFactory.getRequiredColumns() |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory |
VarianceAggregatorFactory.getMergingFactory(AggregatorFactory other) |
Modifier and Type | Method and Description |
---|---|
PostAggregator |
StandardDeviationPostAggregator.decorate(Map<String,AggregatorFactory> aggregators) |
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) |
GroupByQuery |
GroupByQuery.withAggregatorSpecs(List<AggregatorFactory> aggregatorSpecs) |
Constructor and Description |
---|
GroupByQuery(DataSource dataSource,
QuerySegmentSpec querySegmentSpec,
VirtualColumns virtualColumns,
DimFilter dimFilter,
Granularity granularity,
List<DimensionSpec> dimensions,
List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs,
HavingSpec havingSpec,
LimitSpec limitSpec,
Map<String,Object> context) |
Modifier and Type | Method and Description |
---|---|
static Pair<Grouper<io.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey>,Accumulator<Grouper<io.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey>,Row>> |
RowBasedGrouperHelper.createGrouperAccumulatorPair(GroupByQuery query,
boolean isInputRaw,
Map<String,ValueType> rawInputRowSignature,
GroupByQueryConfig config,
com.google.common.base.Supplier<ByteBuffer> bufferSupplier,
int concurrencyHint,
LimitedTemporaryStorage temporaryStorage,
com.fasterxml.jackson.databind.ObjectMapper spillMapper,
AggregatorFactory[] aggregatorFactories)
If isInputRaw is true, transformations such as timestamp truncation and extraction functions have not
been applied to the input rows yet, for example, in a nested query, if an extraction function is being
applied in the outer query to a field of the inner query.
|
Constructor and Description |
---|
BufferGrouper(com.google.common.base.Supplier<ByteBuffer> bufferSupplier,
Grouper.KeySerde<KeyType> keySerde,
ColumnSelectorFactory columnSelectorFactory,
AggregatorFactory[] aggregatorFactories,
int bufferGrouperMaxSize,
float maxLoadFactor,
int initialBuckets) |
ConcurrentGrouper(com.google.common.base.Supplier<ByteBuffer> bufferSupplier,
Grouper.KeySerdeFactory<KeyType> keySerdeFactory,
ColumnSelectorFactory columnSelectorFactory,
AggregatorFactory[] aggregatorFactories,
int bufferGrouperMaxSize,
float bufferGrouperMaxLoadFactor,
int bufferGrouperInitialBuckets,
LimitedTemporaryStorage temporaryStorage,
com.fasterxml.jackson.databind.ObjectMapper spillMapper,
int concurrencyHint) |
SpillingGrouper(com.google.common.base.Supplier<ByteBuffer> bufferSupplier,
Grouper.KeySerdeFactory<KeyType> keySerdeFactory,
ColumnSelectorFactory columnSelectorFactory,
AggregatorFactory[] aggregatorFactories,
int bufferGrouperMaxSize,
float bufferGrouperMaxLoadFactor,
int bufferGrouperInitialBuckets,
LimitedTemporaryStorage temporaryStorage,
com.fasterxml.jackson.databind.ObjectMapper spillMapper,
boolean spillingAllowed) |
Modifier and Type | Method and Description |
---|---|
com.google.common.base.Function<Sequence<Row>,Sequence<Row>> |
NoopLimitSpec.build(List<DimensionSpec> dimensions,
List<AggregatorFactory> aggs,
List<PostAggregator> postAggs) |
com.google.common.base.Function<Sequence<Row>,Sequence<Row>> |
LimitSpec.build(List<DimensionSpec> dimensions,
List<AggregatorFactory> aggs,
List<PostAggregator> postAggs)
Returns a function that applies a limit to an input sequence that is assumed to be sorted on dimensions.
|
com.google.common.base.Function<Sequence<Row>,Sequence<Row>> |
DefaultLimitSpec.build(List<DimensionSpec> dimensions,
List<AggregatorFactory> aggs,
List<PostAggregator> postAggs) |
Modifier and Type | Method and Description |
---|---|
Map<String,AggregatorFactory> |
SegmentAnalysis.getAggregators() |
Constructor and Description |
---|
SegmentAnalysis(String id,
List<org.joda.time.Interval> interval,
Map<String,ColumnAnalysis> columns,
long size,
long numRows,
Map<String,AggregatorFactory> aggregators,
TimestampSpec timestampSpec,
Granularity queryGranularity,
Boolean rollup) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
TimeseriesQuery.getAggregatorSpecs() |
Constructor and Description |
---|
TimeseriesBinaryFn(Granularity granularity,
List<AggregatorFactory> aggregations) |
TimeseriesQuery(DataSource dataSource,
QuerySegmentSpec querySegmentSpec,
boolean descending,
VirtualColumns virtualColumns,
DimFilter dimFilter,
Granularity 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 |
DimensionTopNMetricSpec.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) |
TopNResultBuilder |
DimensionTopNMetricSpec.getResultBuilder(org.joda.time.DateTime timestamp,
DimensionSpec dimSpec,
int threshold,
Comparator comparator,
List<AggregatorFactory> aggFactories,
List<PostAggregator> postAggs) |
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) |
void |
DimensionTopNMetricSpec.verifyPreconditions(List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs) |
TopNQuery |
TopNQuery.withAggregatorSpecs(List<AggregatorFactory> aggregatorSpecs) |
Constructor and Description |
---|
TopNBinaryFn(TopNResultMerger merger,
Granularity 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,
VirtualColumns virtualColumns,
DimensionSpec dimensionSpec,
TopNMetricSpec topNMetricSpec,
int threshold,
QuerySegmentSpec querySegmentSpec,
DimFilter dimFilter,
Granularity granularity,
List<AggregatorFactory> aggregatorSpecs,
List<PostAggregator> postAggregatorSpecs,
Map<String,Object> context) |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory[] |
Metadata.getAggregators() |
Modifier and Type | Method and Description |
---|---|
File |
IndexMerger.append(List<IndexableAdapter> indexes,
AggregatorFactory[] aggregators,
File outDir,
IndexSpec indexSpec) |
File |
IndexMerger.append(List<IndexableAdapter> indexes,
AggregatorFactory[] aggregators,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
protected File |
IndexMergerV9.makeIndexFiles(List<IndexableAdapter> adapters,
AggregatorFactory[] metricAggs,
File outDir,
ProgressIndicator progress,
List<String> mergedDimensions,
List<String> mergedMetrics,
com.google.common.base.Function<ArrayList<Iterable<Rowboat>>,Iterable<Rowboat>> rowMergerFn,
IndexSpec indexSpec) |
protected File |
IndexMerger.makeIndexFiles(List<IndexableAdapter> indexes,
AggregatorFactory[] metricAggs,
File outDir,
ProgressIndicator progress,
List<String> mergedDimensions,
List<String> mergedMetrics,
com.google.common.base.Function<ArrayList<Iterable<Rowboat>>,Iterable<Rowboat>> rowMergerFn,
IndexSpec indexSpec) |
File |
IndexMerger.merge(List<IndexableAdapter> indexes,
boolean rollup,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec) |
File |
IndexMerger.merge(List<IndexableAdapter> indexes,
boolean rollup,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
static Metadata |
Metadata.merge(List<Metadata> toBeMerged,
AggregatorFactory[] overrideMergedAggregators) |
File |
IndexMerger.mergeQueryableIndex(List<QueryableIndex> indexes,
boolean rollup,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec) |
File |
IndexMerger.mergeQueryableIndex(List<QueryableIndex> indexes,
boolean rollup,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
Metadata |
Metadata.setAggregators(AggregatorFactory[] aggregators) |
Constructor and Description |
---|
AggFactoryStringIndexed(AggregatorFactory[] metricAggs) |
RowboatMergeFunction(AggregatorFactory[] metricAggs) |
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,
boolean reportParseExceptions,
InputRow row,
AtomicInteger numEntries,
IncrementalIndex.TimeAndDims key,
ThreadLocal<InputRow> rowContainer,
com.google.common.base.Supplier<InputRow> rowSupplier) |
protected Integer |
OffheapIncrementalIndex.addToFacts(AggregatorFactory[] metrics,
boolean deserializeComplexMetrics,
boolean reportParseExceptions,
InputRow row,
AtomicInteger numEntries,
IncrementalIndex.TimeAndDims key,
ThreadLocal<InputRow> rowContainer,
com.google.common.base.Supplier<InputRow> rowSupplier) |
protected abstract Integer |
IncrementalIndex.addToFacts(AggregatorFactory[] metrics,
boolean deserializeComplexMetrics,
boolean reportParseExceptions,
InputRow row,
AtomicInteger numEntries,
IncrementalIndex.TimeAndDims key,
ThreadLocal<InputRow> rowContainer,
com.google.common.base.Supplier<InputRow> rowSupplier) |
protected Aggregator[] |
OnheapIncrementalIndex.initAggs(AggregatorFactory[] metrics,
com.google.common.base.Supplier<InputRow> rowSupplier,
boolean deserializeComplexMetrics) |
protected BufferAggregator[] |
OffheapIncrementalIndex.initAggs(AggregatorFactory[] metrics,
com.google.common.base.Supplier<InputRow> rowSupplier,
boolean deserializeComplexMetrics) |
protected abstract AggregatorType[] |
IncrementalIndex.initAggs(AggregatorFactory[] metrics,
com.google.common.base.Supplier<InputRow> rowSupplier,
boolean deserializeComplexMetrics) |
protected ColumnSelectorFactory |
IncrementalIndex.makeColumnSelectorFactory(AggregatorFactory agg,
com.google.common.base.Supplier<InputRow> in,
boolean deserializeComplexMetrics) |
static ColumnSelectorFactory |
IncrementalIndex.makeColumnSelectorFactory(VirtualColumns virtualColumns,
AggregatorFactory agg,
com.google.common.base.Supplier<InputRow> in,
boolean deserializeComplexMetrics)
Column selector used at ingestion time for inputs to aggregators.
|
IncrementalIndexSchema.Builder |
IncrementalIndexSchema.Builder.withMetrics(AggregatorFactory[] metrics) |
Constructor and Description |
---|
IncrementalIndexSchema(long minTimestamp,
TimestampSpec timestampSpec,
Granularity gran,
VirtualColumns virtualColumns,
DimensionsSpec dimensionsSpec,
AggregatorFactory[] metrics,
boolean rollup) |
MetricDesc(int index,
AggregatorFactory factory) |
OffheapIncrementalIndex(long minTimestamp,
Granularity gran,
AggregatorFactory[] metrics,
int maxRowCount,
StupidPool<ByteBuffer> bufferPool) |
OffheapIncrementalIndex(long minTimestamp,
Granularity gran,
boolean rollup,
AggregatorFactory[] metrics,
int maxRowCount,
StupidPool<ByteBuffer> bufferPool) |
OnheapIncrementalIndex(long minTimestamp,
Granularity gran,
AggregatorFactory[] metrics,
boolean deserializeComplexMetrics,
boolean reportParseExceptions,
boolean sortFacts,
int maxRowCount) |
OnheapIncrementalIndex(long minTimestamp,
Granularity gran,
AggregatorFactory[] metrics,
int maxRowCount) |
OnheapIncrementalIndex(long minTimestamp,
Granularity gran,
boolean rollup,
DimensionsSpec dimensionsSpec,
AggregatorFactory[] metrics,
int maxRowCount) |
Modifier and Type | Method and Description |
---|---|
AggregatorFactory[] |
DataSchema.getAggregators() |
Constructor and Description |
---|
DataSchema(String dataSource,
Map<String,Object> parser,
AggregatorFactory[] aggregators,
GranularitySpec granularitySpec,
com.fasterxml.jackson.databind.ObjectMapper jsonMapper) |
Modifier and Type | Method and Description |
---|---|
static <T extends AggregatorFactory> |
Aggregations.aggregatorMatches(AggregatorFactory factory,
DimFilter filter,
Class<T> clazz,
com.google.common.base.Predicate<T> predicate)
Returns true if "factory" is an aggregator factory that either matches "predicate" (if filter is null) or is
a filtered aggregator factory whose filter is equal to "filter" and underlying aggregator matches "predicate".
|
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
Aggregation.getAggregatorFactories() |
Modifier and Type | Method and Description |
---|---|
static <T extends AggregatorFactory> |
Aggregations.aggregatorMatches(AggregatorFactory factory,
DimFilter filter,
Class<T> clazz,
com.google.common.base.Predicate<T> predicate)
Returns true if "factory" is an aggregator factory that either matches "predicate" (if filter is null) or is
a filtered aggregator factory whose filter is equal to "filter" and underlying aggregator matches "predicate".
|
static Aggregation |
Aggregation.create(AggregatorFactory aggregatorFactory) |
Modifier and Type | Method and Description |
---|---|
static Aggregation |
Aggregation.create(List<AggregatorFactory> aggregatorFactories,
PostAggregator postAggregator) |
static Aggregation |
Aggregation.createFinalizable(List<AggregatorFactory> aggregatorFactories,
PostAggregator postAggregator,
PostAggregatorFactory finalizingPostAggregatorFactory) |
Modifier and Type | Method and Description |
---|---|
List<AggregatorFactory> |
Grouping.getAggregatorFactories() |
Copyright © 2011–2017. All rights reserved.