public class OnheapIncrementalIndex extends IncrementalIndex<Aggregator>
IncrementalIndex.DimensionDesc, IncrementalIndex.FactsEntry, IncrementalIndex.MetricDesc, IncrementalIndex.TimeAndDims
Modifier and Type | Field and Description |
---|---|
protected int |
maxRowCount |
Constructor and Description |
---|
OnheapIncrementalIndex(IncrementalIndexSchema incrementalIndexSchema,
boolean deserializeComplexMetrics,
boolean reportParseExceptions,
boolean sortFacts,
int maxRowCount) |
OnheapIncrementalIndex(IncrementalIndexSchema incrementalIndexSchema,
boolean reportParseExceptions,
int maxRowCount) |
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 |
---|---|
protected Integer |
addToFacts(AggregatorFactory[] metrics,
boolean deserializeComplexMetrics,
boolean reportParseExceptions,
InputRow row,
AtomicInteger numEntries,
IncrementalIndex.TimeAndDims key,
ThreadLocal<InputRow> rowContainer,
com.google.common.base.Supplier<InputRow> rowSupplier) |
boolean |
canAppendRow() |
void |
close()
Clear out maps to allow GC
NOTE: This is NOT thread-safe with add...
|
protected Aggregator[] |
concurrentGet(int offset) |
protected void |
concurrentRemove(int offset) |
protected void |
concurrentSet(int offset,
Aggregator[] value) |
protected Aggregator[] |
getAggsForRow(int rowOffset) |
protected Object |
getAggVal(Aggregator agg,
int rowOffset,
int aggPosition) |
io.druid.segment.incremental.IncrementalIndex.FactsHolder |
getFacts() |
float |
getMetricFloatValue(int rowOffset,
int aggOffset) |
long |
getMetricLongValue(int rowOffset,
int aggOffset) |
Object |
getMetricObjectValue(int rowOffset,
int aggOffset) |
String |
getOutOfRowsReason() |
protected Aggregator[] |
initAggs(AggregatorFactory[] metrics,
com.google.common.base.Supplier<InputRow> rowSupplier,
boolean deserializeComplexMetrics) |
add, dimsComparator, formatRow, getAggs, getCapabilities, getColumnCapabilities, getDimension, getDimensionHandlers, getDimensionIndex, getDimensionNames, getDimensionOrder, getDimensions, getInterval, getMaxIngestedEventTime, getMaxTime, getMetadata, getMetricAggs, getMetricClass, getMetricIndex, getMetricNames, getMetrics, getMetricType, getMinTime, isEmpty, isRollup, iterableWithPostAggregations, iterator, loadDimensionIterable, makeColumnSelectorFactory, makeColumnSelectorFactory, size
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
forEach, spliterator
public OnheapIncrementalIndex(IncrementalIndexSchema incrementalIndexSchema, boolean deserializeComplexMetrics, boolean reportParseExceptions, boolean sortFacts, int maxRowCount)
public OnheapIncrementalIndex(long minTimestamp, Granularity gran, AggregatorFactory[] metrics, boolean deserializeComplexMetrics, boolean reportParseExceptions, boolean sortFacts, int maxRowCount)
public OnheapIncrementalIndex(long minTimestamp, Granularity gran, boolean rollup, DimensionsSpec dimensionsSpec, AggregatorFactory[] metrics, int maxRowCount)
public OnheapIncrementalIndex(long minTimestamp, Granularity gran, AggregatorFactory[] metrics, int maxRowCount)
public OnheapIncrementalIndex(IncrementalIndexSchema incrementalIndexSchema, boolean reportParseExceptions, int maxRowCount)
public io.druid.segment.incremental.IncrementalIndex.FactsHolder getFacts()
getFacts
in class IncrementalIndex<Aggregator>
protected Aggregator[] initAggs(AggregatorFactory[] metrics, com.google.common.base.Supplier<InputRow> rowSupplier, boolean deserializeComplexMetrics)
initAggs
in class IncrementalIndex<Aggregator>
protected Integer addToFacts(AggregatorFactory[] metrics, boolean deserializeComplexMetrics, boolean reportParseExceptions, InputRow row, AtomicInteger numEntries, IncrementalIndex.TimeAndDims key, ThreadLocal<InputRow> rowContainer, com.google.common.base.Supplier<InputRow> rowSupplier) throws IndexSizeExceededException
addToFacts
in class IncrementalIndex<Aggregator>
IndexSizeExceededException
protected Aggregator[] concurrentGet(int offset)
protected void concurrentSet(int offset, Aggregator[] value)
protected void concurrentRemove(int offset)
public boolean canAppendRow()
canAppendRow
in class IncrementalIndex<Aggregator>
public String getOutOfRowsReason()
getOutOfRowsReason
in class IncrementalIndex<Aggregator>
protected Aggregator[] getAggsForRow(int rowOffset)
getAggsForRow
in class IncrementalIndex<Aggregator>
protected Object getAggVal(Aggregator agg, int rowOffset, int aggPosition)
getAggVal
in class IncrementalIndex<Aggregator>
public float getMetricFloatValue(int rowOffset, int aggOffset)
getMetricFloatValue
in class IncrementalIndex<Aggregator>
public long getMetricLongValue(int rowOffset, int aggOffset)
getMetricLongValue
in class IncrementalIndex<Aggregator>
public Object getMetricObjectValue(int rowOffset, int aggOffset)
getMetricObjectValue
in class IncrementalIndex<Aggregator>
public void close()
close
in interface Closeable
close
in interface AutoCloseable
close
in class IncrementalIndex<Aggregator>
Copyright © 2011–2017. All rights reserved.