public class OffheapIncrementalIndex extends IncrementalIndex<BufferAggregator>
IncrementalIndex.DimensionDesc, IncrementalIndex.FactsEntry, IncrementalIndex.MetricDesc, IncrementalIndex.TimeAndDims
Modifier and Type | Field and Description |
---|---|
protected int |
maxRowCount |
Constructor and Description |
---|
OffheapIncrementalIndex(IncrementalIndexSchema incrementalIndexSchema,
boolean deserializeComplexMetrics,
boolean reportParseExceptions,
boolean sortFacts,
int maxRowCount,
StupidPool<ByteBuffer> bufferPool) |
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) |
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()
NOTE: This is NOT thread-safe with add...
|
protected BufferAggregator[] |
getAggsForRow(int rowOffset) |
protected Object |
getAggVal(BufferAggregator 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 BufferAggregator[] |
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 OffheapIncrementalIndex(IncrementalIndexSchema incrementalIndexSchema, boolean deserializeComplexMetrics, boolean reportParseExceptions, boolean sortFacts, int maxRowCount, StupidPool<ByteBuffer> bufferPool)
public OffheapIncrementalIndex(long minTimestamp, Granularity gran, boolean rollup, AggregatorFactory[] metrics, int maxRowCount, StupidPool<ByteBuffer> bufferPool)
public OffheapIncrementalIndex(long minTimestamp, Granularity gran, AggregatorFactory[] metrics, int maxRowCount, StupidPool<ByteBuffer> bufferPool)
public io.druid.segment.incremental.IncrementalIndex.FactsHolder getFacts()
getFacts
in class IncrementalIndex<BufferAggregator>
protected BufferAggregator[] initAggs(AggregatorFactory[] metrics, com.google.common.base.Supplier<InputRow> rowSupplier, boolean deserializeComplexMetrics)
initAggs
in class IncrementalIndex<BufferAggregator>
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<BufferAggregator>
IndexSizeExceededException
public boolean canAppendRow()
canAppendRow
in class IncrementalIndex<BufferAggregator>
public String getOutOfRowsReason()
getOutOfRowsReason
in class IncrementalIndex<BufferAggregator>
protected BufferAggregator[] getAggsForRow(int rowOffset)
getAggsForRow
in class IncrementalIndex<BufferAggregator>
protected Object getAggVal(BufferAggregator agg, int rowOffset, int aggPosition)
getAggVal
in class IncrementalIndex<BufferAggregator>
public float getMetricFloatValue(int rowOffset, int aggOffset)
getMetricFloatValue
in class IncrementalIndex<BufferAggregator>
public long getMetricLongValue(int rowOffset, int aggOffset)
getMetricLongValue
in class IncrementalIndex<BufferAggregator>
public Object getMetricObjectValue(int rowOffset, int aggOffset)
getMetricObjectValue
in class IncrementalIndex<BufferAggregator>
public void close()
close
in interface Closeable
close
in interface AutoCloseable
close
in class IncrementalIndex<BufferAggregator>
Copyright © 2011–2017. All rights reserved.