public class OffheapIncrementalIndex extends IncrementalIndex<BufferAggregator>
dimensions
Constructor and Description |
---|
OffheapIncrementalIndex(IncrementalIndexSchema incrementalIndexSchema,
StupidPool<ByteBuffer> bufferPool,
boolean deserializeComplexMetrics,
int maxTotalBufferSize) |
OffheapIncrementalIndex(long minTimestamp,
QueryGranularity gran,
AggregatorFactory[] metrics,
StupidPool<ByteBuffer> bufferPool,
boolean deserializeComplexMetrics,
int maxTotalBufferSize) |
Modifier and Type | Method and Description |
---|---|
protected Integer |
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) |
boolean |
canAppendRow() |
void |
close() |
protected BufferAggregator[] |
getAggsForRow(int rowOffset) |
protected Object |
getAggVal(BufferAggregator agg,
int rowOffset,
int aggPosition) |
ConcurrentNavigableMap<io.druid.segment.incremental.IncrementalIndex.TimeAndDims,Integer> |
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<io.druid.data.input.InputRow> rowSupplier,
boolean deserializeComplexMetrics) |
protected io.druid.segment.incremental.IncrementalIndex.DimDim |
makeDimDim(String dimension) |
add, formatRow, getAggs, getCapabilities, getDimension, getDimensionIndex, getDimensions, getDimValues, getInterval, getMaxIngestedEventTime, getMaxTime, getMetricAggs, getMetricIndex, getMetricNames, getMetricType, getMinTime, getSubMap, isEmpty, iterableWithPostAggregations, iterator, makeColumnSelectorFactory, size, updateMaxIngestedTime
public OffheapIncrementalIndex(IncrementalIndexSchema incrementalIndexSchema, StupidPool<ByteBuffer> bufferPool, boolean deserializeComplexMetrics, int maxTotalBufferSize)
public OffheapIncrementalIndex(long minTimestamp, QueryGranularity gran, AggregatorFactory[] metrics, StupidPool<ByteBuffer> bufferPool, boolean deserializeComplexMetrics, int maxTotalBufferSize)
public ConcurrentNavigableMap<io.druid.segment.incremental.IncrementalIndex.TimeAndDims,Integer> getFacts()
getFacts
in class IncrementalIndex<BufferAggregator>
protected io.druid.segment.incremental.IncrementalIndex.DimDim makeDimDim(String dimension)
makeDimDim
in class IncrementalIndex<BufferAggregator>
protected BufferAggregator[] initAggs(AggregatorFactory[] metrics, com.google.common.base.Supplier<io.druid.data.input.InputRow> rowSupplier, boolean deserializeComplexMetrics)
initAggs
in class IncrementalIndex<BufferAggregator>
protected Integer 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) 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–2015. All rights reserved.