Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Z 

A

AbstractBufferHashGrouper<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
 
AbstractBufferHashGrouper(Supplier<ByteBuffer>, Grouper.KeySerde<KeyType>, AggregatorAdapters, int, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
AbstractDimensionSelector - Class in org.apache.druid.segment
An abstract class that provides an implementation of AbstractDimensionSelector.getObject().
AbstractDimensionSelector() - Constructor for class org.apache.druid.segment.AbstractDimensionSelector
 
AbstractIndex - Class in org.apache.druid.segment
 
AbstractIndex() - Constructor for class org.apache.druid.segment.AbstractIndex
 
AbstractOptimizableDimFilter - Class in org.apache.druid.query.filter
Base class for DimFilters that support optimization.
AbstractOptimizableDimFilter() - Constructor for class org.apache.druid.query.filter.AbstractOptimizableDimFilter
 
AbstractPrioritizedCallable<V> - Class in org.apache.druid.query
 
AbstractPrioritizedCallable(int) - Constructor for class org.apache.druid.query.AbstractPrioritizedCallable
 
AbstractSegment - Class in org.apache.druid.segment
Deprecated.
use Segment directly as this does nothing
AbstractSegment() - Constructor for class org.apache.druid.segment.AbstractSegment
Deprecated.
 
accept(String) - Method in class org.apache.druid.query.search.AllSearchQuerySpec
 
accept(String) - Method in class org.apache.druid.query.search.ContainsSearchQuerySpec
 
accept(String) - Method in class org.apache.druid.query.search.FragmentSearchQuerySpec
 
accept(String) - Method in class org.apache.druid.query.search.RegexSearchQuerySpec
 
accept(String) - Method in interface org.apache.druid.query.search.SearchQuerySpec
 
accountLoopIterations(long) - Method in class org.apache.druid.query.monomorphicprocessing.SpecializationState
Accounts the number of loop iterations, made when processing queries without specialized algorithm, i.
acquireReferences() - Method in class org.apache.druid.segment.join.HashJoinSegment
 
acquireReferences() - Method in class org.apache.druid.segment.join.JoinableClause
 
acquireReferences() - Method in class org.apache.druid.segment.join.lookup.LookupJoinable
 
acquireReferences() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
acquireReferences() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinable
 
acquireReferences() - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
 
acquireReferences() - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
acquireReferences() - Method in interface org.apache.druid.segment.ReferenceCountedObject
This method is expected to increment a reference count and provide a Closeable that decrements the reference count when closed.
acquireReferences() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
add(int) - Method in interface org.apache.druid.collections.bitmap.MutableBitmap
Add the specified integer to the bitmap.
add(int) - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
add(int) - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
add(int) - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
add(Integer) - Method in class org.apache.druid.collections.IntegerSet
 
add(ResponseContext.BaseKey, Object) - Method in class org.apache.druid.query.context.ResponseContext
Adds (merges) a new value associated with a key to an old value.
add(ExecutorServiceMonitor.MetricEmitter) - Method in class org.apache.druid.query.ExecutorServiceMonitor
 
add(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferIntList
 
add(String, ValueType) - Method in class org.apache.druid.segment.column.RowSignature.Builder
Add a column to this signature.
add(double) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarDoublesSerializer
 
add(float) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarFloatsSerializer
 
add(long) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarLongsSerializer
 
add(double) - Method in interface org.apache.druid.segment.data.ColumnarDoublesSerializer
 
add(float) - Method in interface org.apache.druid.segment.data.ColumnarFloatsSerializer
 
add(long) - Method in interface org.apache.druid.segment.data.ColumnarLongsSerializer
 
add(double) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSerializer
 
add(float) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarFloatsSerializer
 
add(long) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarLongsSerializer
 
add(long) - Method in class org.apache.druid.segment.data.IntermediateColumnarLongsSerializer
 
add(InputRow) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
Adds a new row.
add(InputRow, boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
addAggregator(AggregatorFactory) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
addAggregators(List<AggregatorFactory>) - Method in class org.apache.druid.segment.column.RowSignature.Builder
 
addAll(Collection<? extends Integer>) - Method in class org.apache.druid.collections.IntegerSet
 
addAll(ReadableVectorMatch, VectorMatch) - Method in class org.apache.druid.query.filter.vector.VectorMatch
Adds all rows from "other" to this object, using "scratch" as scratch space if needed.
addAll(RowSignature) - Method in class org.apache.druid.segment.column.RowSignature.Builder
 
addChild(Node) - Method in class org.apache.druid.collections.spatial.Node
 
addChild(Node) - Method in class org.apache.druid.collections.spatial.Point
 
addDimension(String) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
addDimension(String, String) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
addDimension(DimensionSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
addDimensions(List<DimensionSpec>) - Method in class org.apache.druid.segment.column.RowSignature.Builder
 
addEntry(Comparable, Object, Object[]) - Method in class org.apache.druid.query.topn.TopNLexicographicResultBuilder
 
addEntry(DimensionAndMetricValueExtractor) - Method in class org.apache.druid.query.topn.TopNLexicographicResultBuilder
 
addEntry(Comparable, Object, Object[]) - Method in class org.apache.druid.query.topn.TopNNumericResultBuilder
 
addEntry(DimensionAndMetricValueExtractor) - Method in class org.apache.druid.query.topn.TopNNumericResultBuilder
 
addEntry(Comparable, Object, Object[]) - Method in interface org.apache.druid.query.topn.TopNResultBuilder
 
addEntry(DimensionAndMetricValueExtractor) - Method in interface org.apache.druid.query.topn.TopNResultBuilder
 
addMetric(String, Object) - Method in class org.apache.druid.query.timeseries.TimeseriesResultBuilder
 
addOffset(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
addOrderByColumn(String) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
addOrderByColumn(String, OrderByColumnSpec.Direction) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
addOrderByColumn(OrderByColumnSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
addPostAggregators(List<PostAggregator>) - Method in class org.apache.druid.segment.column.RowSignature.Builder
 
addProcessedRows(long) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
addProcessedRows(long) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
Called with the number of rows, processed via each cursor, processed for the query within the segment.
addSerde(ColumnPartSerde) - Method in class org.apache.druid.segment.column.ColumnDescriptor.Builder
 
addTimeColumn() - Method in class org.apache.druid.segment.column.RowSignature.Builder
 
addToBitmapIndex(Node) - Method in class org.apache.druid.collections.spatial.Node
 
addToFacts(InputRow, IncrementalIndexRow, ThreadLocal<InputRow>, Supplier<InputRow>, boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
addToFacts(InputRow, IncrementalIndexRow, ThreadLocal<InputRow>, Supplier<InputRow>, boolean) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
addToFacts(InputRow, IncrementalIndexRow, ThreadLocal<InputRow>, Supplier<InputRow>, boolean) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
addValue(int) - Method in class org.apache.druid.segment.data.CompressedColumnarIntsSerializer
 
addValue(int) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSerializer
 
addValue(int) - Method in class org.apache.druid.segment.data.SingleValueColumnarIntsSerializer
 
addValue(int) - Method in class org.apache.druid.segment.data.VSizeColumnarIntsSerializer
 
addValues(IndexedInts) - Method in class org.apache.druid.segment.data.ColumnarMultiIntsSerializer
 
addValues(IndexedInts) - Method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSerializer
 
addValues(IndexedInts) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiIntsSerializer
 
adjustTableWhenFull() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
advance() - Method in interface org.apache.druid.segment.Cursor
 
advance() - Method in class org.apache.druid.segment.join.PostJoinCursor
 
advance() - Method in class org.apache.druid.segment.RowBasedCursor
 
advance() - Method in class org.apache.druid.segment.RowWalker
 
advance() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
advance() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
advance() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
advance() - Method in interface org.apache.druid.segment.vector.VectorCursor
Advances the cursor, skipping forward a number of rows equal to the current vector size.
advance() - Method in interface org.apache.druid.segment.vector.VectorOffset
Advances by one batch.
advanceCursorWithinBucket() - Method in class org.apache.druid.query.vector.VectorCursorGranularizer
Return true, and advances the cursor, if it can be advanced within the current time bucket.
advanceIfNeeded(int) - Method in class org.apache.druid.collections.bitmap.ConcisePeekableIteratorAdapter
 
advanceIfNeeded(int) - Method in class org.apache.druid.collections.bitmap.PeekableIteratorAdapter
 
advanceUninterruptibly() - Method in interface org.apache.druid.segment.Cursor
 
advanceUninterruptibly() - Method in class org.apache.druid.segment.join.PostJoinCursor
 
advanceUninterruptibly() - Method in class org.apache.druid.segment.RowBasedCursor
 
afterAggregateHook(int) - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
Called after a row is aggregated.
afterAggregateHook(int) - Method in class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
afterAggregateHook(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
aggregate() - Method in interface org.apache.druid.query.aggregation.Aggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.any.NumericAnyAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.NumericAnyBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.any.NumericAnyVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.any.NumericAnyVectorAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.any.NumericNilVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.any.NumericNilVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.any.StringAnyVectorAggregator
 
aggregate(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Aggregates metric values into the given aggregate byte representation Implementations of this method must read in the aggregate value from the buffer at the given position, aggregate the next element of data and write the updated aggregate value back into the buffer.
aggregate() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.CountAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.CountVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.CountVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregator
 
aggregate(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleMaxBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.DoubleMaxVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.DoubleMaxVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregator
 
aggregate(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleMinBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.DoubleMinVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.DoubleMinVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregator
 
aggregate(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleSumBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.DoubleSumVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.DoubleSumVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.FilteredVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.FilteredVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.first.NumericFirstAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.NumericFirstBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregator
 
aggregate(ByteBuffer, int, float) - Method in class org.apache.druid.query.aggregation.FloatMaxBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.FloatMaxVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.FloatMaxVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.FloatMinAggregator
 
aggregate(ByteBuffer, int, float) - Method in class org.apache.druid.query.aggregation.FloatMinBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.FloatMinVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.FloatMinVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.FloatSumAggregator
 
aggregate(ByteBuffer, int, float) - Method in class org.apache.druid.query.aggregation.FloatSumBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.FloatSumVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.FloatSumVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.HistogramAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.last.NumericLastAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.NumericLastBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.LongMaxAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMaxBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.LongMaxVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.LongMaxVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.LongMinAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMinBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.LongMinVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.LongMinVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.LongSumAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongSumBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.LongSumVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.LongSumVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.NoopAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.NoopVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.NoopVectorAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.NullableNumericVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.NullableNumericVectorAggregator
 
aggregate(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
aggregate(ByteBuffer, int, float) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
 
aggregate() - Method in class org.apache.druid.query.aggregation.StringColumnDoubleAggregatorWrapper
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.StringColumnDoubleBufferAggregatorWrapper
 
aggregate() - Method in class org.apache.druid.query.aggregation.StringColumnFloatAggregatorWrapper
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.StringColumnFloatBufferAggregatorWrapper
 
aggregate() - Method in class org.apache.druid.query.aggregation.StringColumnLongAggregatorWrapper
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.StringColumnLongBufferAggregatorWrapper
 
aggregate() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
aggregate(ByteBuffer, int, int, int) - Method in interface org.apache.druid.query.aggregation.VectorAggregator
Aggregate a range of rows into a single aggregation slot.
aggregate(ByteBuffer, int, int[], int[], int) - Method in interface org.apache.druid.query.aggregation.VectorAggregator
Aggregate a list of rows ("rows") into a list of aggregation slots ("positions").
aggregate(KeyType, int) - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
aggregate(KeyType, int) - Method in class org.apache.druid.query.groupby.epinephelinae.ConcurrentGrouper
 
aggregate(KeyType, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
Aggregate the current row with the provided key.
aggregate(KeyType) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
Aggregate the current row with the provided key.
aggregate(int) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper
 
aggregate(Integer) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper
Deprecated.
Please use IntGrouper.aggregate(int) instead.
aggregate(Integer, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper
Deprecated.
aggregate(KeyType, int) - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
 
aggregate(KeyType, int) - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
 
aggregate(KeyType) - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
 
aggregateBuffered(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Call BufferAggregator.aggregate(ByteBuffer, int) on all of our aggregators.
AggregateCombiner<T> - Interface in org.apache.druid.query.aggregation
AggregateCombiner is used to fold rollup aggregation results from serveral "rows" of different indexes during index merging (see IndexMerger).
aggregateKeyHash(int) - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
aggregateKeyHash(int) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper
 
AggregateResult - Class in org.apache.druid.query.groupby.epinephelinae
 
AggregateTopNMetricFirstAlgorithm - Class in org.apache.druid.query.topn
This TopNAlgorithm is tailored to processing aggregates on high cardility columns which are likely to have larger result sets.
AggregateTopNMetricFirstAlgorithm(StorageAdapter, TopNQuery, NonBlockingPool<ByteBuffer>) - Constructor for class org.apache.druid.query.topn.AggregateTopNMetricFirstAlgorithm
 
aggregateVector(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
aggregateVector(ByteBuffer, int, int[], int[]) - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
aggregateVector(Memory, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
aggregateVector(Memory, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
 
aggregateVector(Memory, int, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.VectorGrouper
Aggregate the current vector of rows from "startRow" to "endRow" using the provided keys.
Aggregator - Interface in org.apache.druid.query.aggregation
An Aggregator is an object that can aggregate metrics.
AggregatorAdapters - Class in org.apache.druid.query.aggregation
A class that helps query engines use Buffer- or VectorAggregators in a consistent way.
AggregatorArrayProvider(DimensionSelector, TopNQuery, int, StorageAdapter) - Constructor for class org.apache.druid.query.topn.BaseTopNAlgorithm.AggregatorArrayProvider
 
AggregatorFactory - Class in org.apache.druid.query.aggregation
AggregatorFactory is a strategy (in the terms of Design Patterns) that represents column aggregation, e.g.
AggregatorFactory() - Constructor for class org.apache.druid.query.aggregation.AggregatorFactory
 
AggregatorFactoryNotMergeableException - Exception in org.apache.druid.query.aggregation
 
AggregatorFactoryNotMergeableException(String, Object...) - Constructor for exception org.apache.druid.query.aggregation.AggregatorFactoryNotMergeableException
 
AggregatorFactoryNotMergeableException(AggregatorFactory, AggregatorFactory) - Constructor for exception org.apache.druid.query.aggregation.AggregatorFactoryNotMergeableException
 
aggregatorPositions() - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Return the individual positions of each aggregator within a hypothetical buffer of size AggregatorAdapters.spaceNeeded().
aggregators(List<AggregatorFactory>) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
aggregators(AggregatorFactory...) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
aggregators - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
aggregators(List<? extends AggregatorFactory>) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
aggregators(AggregatorFactory...) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
AggregatorsModule - Class in org.apache.druid.jackson
 
AggregatorsModule() - Constructor for class org.apache.druid.jackson.AggregatorsModule
 
AggregatorsModule.AggregatorFactoryMixin - Interface in org.apache.druid.jackson
 
AggregatorsModule.PostAggregatorMixin - Interface in org.apache.druid.jackson
 
AggregatorUtil - Class in org.apache.druid.query.aggregation
 
AggregatorUtil() - Constructor for class org.apache.druid.query.aggregation.AggregatorUtil
 
algorithm(TopNAlgorithm) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
algorithm(TopNAlgorithm) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
 
AllColumnIncluderator - Class in org.apache.druid.query.metadata.metadata
 
AllColumnIncluderator() - Constructor for class org.apache.druid.query.metadata.metadata.AllColumnIncluderator
 
allFalse() - Static method in class org.apache.druid.query.filter.vector.VectorMatch
Creates a match that matches nothing.
allFalse(BitmapIndexSelector) - Static method in class org.apache.druid.segment.filter.Filters
 
AllNullColumnSelectorFactory - Class in org.apache.druid.segment.join.filter
 
AllNullColumnSelectorFactory() - Constructor for class org.apache.druid.segment.join.filter.AllNullColumnSelectorFactory
 
allocateBuffer() - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
allocateBuffer() - Method in class org.apache.druid.segment.writeout.HeapByteBufferWriteOutBytes
 
allocateOutBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.LZFCompressor
 
allowReturnPartialResults(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
AllSearchQuerySpec - Class in org.apache.druid.query.search
 
AllSearchQuerySpec() - Constructor for class org.apache.druid.query.search.AllSearchQuerySpec
 
allTrue(int) - Static method in class org.apache.druid.query.filter.vector.VectorMatch
Creates a match that matches everything up to "numRows".
allTrue(BitmapIndexSelector) - Static method in class org.apache.druid.segment.filter.Filters
 
ALPHANUMERIC - Static variable in class org.apache.druid.query.ordering.StringComparators
 
ALPHANUMERIC_CACHE_ID - Static variable in class org.apache.druid.query.ordering.StringComparators
 
ALPHANUMERIC_NAME - Static variable in class org.apache.druid.query.ordering.StringComparators
 
AlphanumericComparator() - Constructor for class org.apache.druid.query.ordering.StringComparators.AlphanumericComparator
 
AlphaNumericTopNMetricSpec - Class in org.apache.druid.query.topn
 
AlphaNumericTopNMetricSpec(String) - Constructor for class org.apache.druid.query.topn.AlphaNumericTopNMetricSpec
 
ALWAYS_FALSE - Static variable in interface org.apache.druid.query.filter.DruidDoublePredicate
 
ALWAYS_FALSE - Static variable in interface org.apache.druid.query.filter.DruidFloatPredicate
 
ALWAYS_FALSE - Static variable in interface org.apache.druid.query.filter.DruidLongPredicate
 
ALWAYS_TRUE - Static variable in interface org.apache.druid.query.filter.DruidDoublePredicate
 
ALWAYS_TRUE - Static variable in interface org.apache.druid.query.filter.DruidLongPredicate
 
AlwaysHavingSpec - Class in org.apache.druid.query.groupby.having
A "having" spec that always evaluates to true
AlwaysHavingSpec() - Constructor for class org.apache.druid.query.groupby.having.AlwaysHavingSpec
 
ANALYSIS_TYPES_CACHE_PREFIX - Static variable in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
The SegmentMetadataQuery cache key may contain UTF-8 column name strings.
analysisTypes(SegmentMetadataQuery.AnalysisType...) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
analysisTypes(EnumSet<SegmentMetadataQuery.AnalysisType>) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
analyze(Segment) - Method in class org.apache.druid.query.metadata.SegmentAnalyzer
 
analyzeFilter(Filter, ColumnSelectorBitmapIndexSelector, QueryMetrics) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
analyzingCardinality() - Method in class org.apache.druid.query.metadata.SegmentAnalyzer
 
analyzingInterval() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
analyzingMinMax() - Method in class org.apache.druid.query.metadata.SegmentAnalyzer
 
analyzingSize() - Method in class org.apache.druid.query.metadata.SegmentAnalyzer
 
and(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
and(DimFilter...) - Static method in class org.apache.druid.query.filter.DimFilters
 
and(List<DimFilter>) - Static method in class org.apache.druid.query.filter.DimFilters
 
and(ColumnCapabilities.Capable) - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
and(List<Filter>) - Static method in class org.apache.druid.segment.filter.Filters
Create a filter representing an AND relationship across a list of filters.
AndDimFilter - Class in org.apache.druid.query.filter
 
AndDimFilter(List<DimFilter>) - Constructor for class org.apache.druid.query.filter.AndDimFilter
 
AndDimFilter(DimFilter...) - Constructor for class org.apache.druid.query.filter.AndDimFilter
 
AndFilter - Class in org.apache.druid.segment.filter
 
AndFilter(List<Filter>) - Constructor for class org.apache.druid.segment.filter.AndFilter
 
AndFilter(Set<Filter>) - Constructor for class org.apache.druid.segment.filter.AndFilter
 
AndHavingSpec - Class in org.apache.druid.query.groupby.having
The logical "and" operator for the "having" clause.
AndHavingSpec(List<HavingSpec>) - Constructor for class org.apache.druid.query.groupby.having.AndHavingSpec
 
andNot(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
any(ExpressionPlan.Trait...) - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
append(List<IndexableAdapter>, AggregatorFactory[], File, IndexSpec, SegmentWriteOutMediumFactory) - Method in interface org.apache.druid.segment.IndexMerger
 
append(List<IndexableAdapter>, AggregatorFactory[], File, IndexSpec, SegmentWriteOutMediumFactory) - Method in class org.apache.druid.segment.IndexMergerV9
 
appendBoolean(boolean) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendByte(byte) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendByteArray(byte[]) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendCacheable(Cacheable) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendCacheables(Collection<? extends Cacheable>) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
Add a collection of Cacheables to the cache key.
appendCacheablesIgnoringOrder(Collection<? extends Cacheable>) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
Add a collection of Cacheables to the cache key.
appendDouble(double) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendDoubleArray(double[]) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendFloat(float) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendFloatArray(float[]) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendInt(int) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendString(String) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
appendStrings(Collection<String>) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
Add a collection of strings to the cache key.
appendStringsIgnoringOrder(Collection<String>) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
Add a collection of strings to the cache key.
apply(String, int, Object) - Method in interface org.apache.druid.query.CacheStrategy.AddToResultFunction
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.CaseInsensitiveContainsExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.ContainsExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.IPv4AddressMatchExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.IPv4AddressParseExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.IPv4AddressStringifyExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.LikeExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.LookupExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.RegexpExtractExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.RegexpLikeExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.TimestampCeilExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.TimestampExtractExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.TimestampFormatExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.TimestampParseExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.TimestampShiftExprMacro
 
apply(List<Expr>) - Method in class org.apache.druid.query.expression.TrimExprMacro
 
apply(Object) - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
apply(long) - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
apply(Object) - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
apply(long) - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
apply(Object) - Method in class org.apache.druid.query.extraction.DimExtractionFn
 
apply(long) - Method in class org.apache.druid.query.extraction.DimExtractionFn
 
apply(Object) - Method in interface org.apache.druid.query.extraction.ExtractionFn
The "extraction" function.
apply(String) - Method in interface org.apache.druid.query.extraction.ExtractionFn
The "extraction" function.
apply(long) - Method in interface org.apache.druid.query.extraction.ExtractionFn
The "extraction" function.
apply(String) - Method in class org.apache.druid.query.extraction.FunctionalExtraction
 
apply(Object) - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
apply(long) - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
apply(Object) - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
apply(long) - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.LowerExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
apply(String) - Method in class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.StrlenExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
apply(long) - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
apply(Object) - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
apply(String) - Method in class org.apache.druid.query.extraction.UpperExtractionFn
 
apply(ResultRow, ResultRow) - Method in class org.apache.druid.query.groupby.epinephelinae.GroupByBinaryFnV2
 
apply(int) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper.IntGrouperHashFunction
 
apply(String) - Method in class org.apache.druid.query.lookup.LookupExtractor
Apply a particular lookup methodology to the input string
apply(Object) - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
apply(String) - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
apply(long) - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
apply(Result<SearchResultValue>, Result<SearchResultValue>) - Method in class org.apache.druid.query.search.SearchBinaryFn
 
apply(Result<TimeseriesResultValue>, Result<TimeseriesResultValue>) - Method in class org.apache.druid.query.timeseries.TimeseriesBinaryFn
 
apply(Result<TopNResultValue>, Result<TopNResultValue>) - Method in class org.apache.druid.query.topn.TopNBinaryFn
 
apply(Cursor, TopNQueryMetrics) - Method in class org.apache.druid.query.topn.TopNMapFn
 
apply(InputRow) - Method in class org.apache.druid.segment.incremental.SpatialDimensionRowTransformer
 
applyAll(Iterable<String>) - Method in class org.apache.druid.query.lookup.LookupExtractor
 
applyAsInt(Integer) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper.IntGrouperHashFunction
 
applyDouble(double) - Method in interface org.apache.druid.query.filter.DruidDoublePredicate
 
applyFloat(float) - Method in interface org.apache.druid.query.filter.DruidFloatPredicate
 
applyInContext(Context, Object) - Method in class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
applyLong(long) - Method in interface org.apache.druid.query.filter.DruidLongPredicate
 
applyNull() - Method in interface org.apache.druid.query.filter.DruidDoublePredicate
 
applyNull() - Method in interface org.apache.druid.query.filter.DruidFloatPredicate
 
applyNull() - Method in interface org.apache.druid.query.filter.DruidLongPredicate
 
applyObject(Object) - Method in class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
applyPostMergeDecoration() - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
applyPostProcessing(Sequence<ResultRow>, GroupByQuery) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Apply the GroupByQuery "postProcessingFn", which is responsible for HavingSpec and LimitSpec.
applyPostProcessing(Sequence<ResultRow>, GroupByQuery) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
applyPostProcessing(Sequence<ResultRow>, GroupByQuery) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
applyPreMergeDecoration() - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
APPROX_HIST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
APPROX_HIST_FOLDING_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
areDictionaryValuesSorted() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
If the column is dictionary encoded, are those values sorted? Useful to know for optimizations that can defer looking up values and allowing sorting with the dictionary ids directly
areDictionaryValuesSorted() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
areDictionaryValuesUnique() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
If the column is dictionary encoded, is there a 1:1 mapping of dictionary ids to values? If this is true, it unlocks optimizations such as allowing for things like grouping directly on dictionary ids and deferred value lookup
areDictionaryValuesUnique() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
areSomeColumnsFromJoin(Collection<String>) - Method in class org.apache.druid.segment.join.filter.JoinableClauses
 
ARITHMETIC - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
ArithmeticPostAggregator - Class in org.apache.druid.query.aggregation.post
 
ArithmeticPostAggregator(String, String, List<PostAggregator>) - Constructor for class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
ArithmeticPostAggregator(String, String, List<PostAggregator>, String) - Constructor for class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
ArithmeticPostAggregator.Ordering - Enum in org.apache.druid.query.aggregation.post
 
ARRAY_OF_DOUBLES_SKETCH_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_SET_OP_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_T_TEST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_TO_ESTIMATE_AND_BOUNDS_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_TO_ESTIMATE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_TO_MEANS_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_TO_NUM_ENTRIES_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_TO_QUANTILES_SKETCH_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_TO_STRING_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ARRAY_OF_DOUBLES_SKETCH_TO_VARIANCES_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
ArrayBasedIndexedInts - Class in org.apache.druid.segment.data
 
ArrayBasedIndexedInts() - Constructor for class org.apache.druid.segment.data.ArrayBasedIndexedInts
 
ArrayBasedIndexedInts(int[]) - Constructor for class org.apache.druid.segment.data.ArrayBasedIndexedInts
 
as(Class<T>) - Method in interface org.apache.druid.segment.Segment
Request an implementation of a particular interface.
asc(String) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
ascending(String...) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
asInputStream() - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
asInputStream() - Method in class org.apache.druid.segment.writeout.WriteOutBytes
Creates a finite InputStream with the bytes that are written to this WriteOutBytes so far.
asMap(ObjectMapper) - Method in class org.apache.druid.segment.IndexSpec
 
asQueryableIndex() - Method in class org.apache.druid.segment.IncrementalIndexSegment
 
asQueryableIndex() - Method in class org.apache.druid.segment.join.HashJoinSegment
 
asQueryableIndex() - Method in class org.apache.druid.segment.QueryableIndexSegment
 
asQueryableIndex() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
asQueryableIndex() - Method in class org.apache.druid.segment.RowBasedSegment
 
asQueryableIndex() - Method in interface org.apache.druid.segment.Segment
 
asStorageAdapter() - Method in class org.apache.druid.segment.IncrementalIndexSegment
 
asStorageAdapter() - Method in class org.apache.druid.segment.join.HashJoinSegment
 
asStorageAdapter() - Method in class org.apache.druid.segment.QueryableIndexSegment
 
asStorageAdapter() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
asStorageAdapter() - Method in class org.apache.druid.segment.RowBasedSegment
 
asStorageAdapter() - Method in interface org.apache.druid.segment.Segment
 
asVisual() - Method in class org.apache.druid.query.aggregation.Histogram
Returns a visual representation of a histogram object.
AutoStrategy - Class in org.apache.druid.query.search
 
awaitTermination(long, TimeUnit) - Method in class org.apache.druid.query.PrioritizedExecutorService
 

B

baseAggregatorOffset - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
BaseArrayProvider(DimensionSelector, TopNQuery, StorageAdapter) - Constructor for class org.apache.druid.query.topn.BaseTopNAlgorithm.BaseArrayProvider
 
BaseColumn - Interface in org.apache.druid.segment.column
 
BaseDoubleColumnValueSelector - Interface in org.apache.druid.segment
Double value selecting polymorphic "part" of the ColumnValueSelector interface.
BaseDoubleVectorValueSelector - Class in org.apache.druid.segment.vector
 
BaseDoubleVectorValueSelector(ReadableVectorOffset) - Constructor for class org.apache.druid.segment.vector.BaseDoubleVectorValueSelector
 
BaseFilteredDimensionSpec - Class in org.apache.druid.query.dimension
 
BaseFilteredDimensionSpec(DimensionSpec) - Constructor for class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
BaseFloatColumnValueSelector - Interface in org.apache.druid.segment
Float value selecting polymorphic "part" of the ColumnValueSelector interface.
BaseFloatVectorValueSelector - Class in org.apache.druid.segment.vector
 
BaseFloatVectorValueSelector(ReadableVectorOffset) - Constructor for class org.apache.druid.segment.vector.BaseFloatVectorValueSelector
 
baseIterator - Variable in class org.apache.druid.segment.ForwardingRowIterator
 
BaseLongColumnValueSelector - Interface in org.apache.druid.segment
Long value selecting polymorphic "part" of the ColumnValueSelector interface.
BaseLongVectorValueSelector - Class in org.apache.druid.segment.vector
 
BaseLongVectorValueSelector(ReadableVectorOffset) - Constructor for class org.apache.druid.segment.vector.BaseLongVectorValueSelector
 
BaseNullableColumnValueSelector - Interface in org.apache.druid.segment
Null value checking polymorphic "part" of the ColumnValueSelector interface for primitive values.
baseObject - Variable in class org.apache.druid.segment.ReferenceCountingCloseableObject
 
BaseObjectColumnValueSelector<T> - Interface in org.apache.druid.segment
Object value selecting polymorphic "part" of the ColumnValueSelector interface.
basePredicateString - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
BaseProgressIndicator - Class in org.apache.druid.segment
 
BaseProgressIndicator() - Constructor for class org.apache.druid.segment.BaseProgressIndicator
 
BaseQuery<T> - Class in org.apache.druid.query
 
BaseQuery(DataSource, QuerySegmentSpec, boolean, Map<String, Object>) - Constructor for class org.apache.druid.query.BaseQuery
 
BaseQuery(DataSource, QuerySegmentSpec, boolean, Map<String, Object>, Granularity) - Constructor for class org.apache.druid.query.BaseQuery
 
baseSelector - Variable in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
BaseSingleValueDimensionSelector - Class in org.apache.druid.segment
 
BaseSingleValueDimensionSelector() - Constructor for class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
BaseTopNAlgorithm<DimValSelector,DimValAggregateStore,Parameters extends TopNParams> - Class in org.apache.druid.query.topn
 
BaseTopNAlgorithm(StorageAdapter) - Constructor for class org.apache.druid.query.topn.BaseTopNAlgorithm
 
BaseTopNAlgorithm.AggregatorArrayProvider - Class in org.apache.druid.query.topn
 
BaseTopNAlgorithm.BaseArrayProvider<T> - Class in org.apache.druid.query.topn
 
BaseVectorValueMatcher - Class in org.apache.druid.query.filter.vector
 
BaseVectorValueMatcher(VectorSizeInspector) - Constructor for class org.apache.druid.query.filter.vector.BaseVectorValueMatcher
 
batchIterator() - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
 
batchIterator() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
BatchIteratorAdapter - Class in org.apache.druid.collections.bitmap
 
BatchIteratorAdapter(IntIterator) - Constructor for class org.apache.druid.collections.bitmap.BatchIteratorAdapter
 
batchSize(int) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
bins - Variable in class org.apache.druid.query.aggregation.Histogram
 
bitmap - Variable in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
BitmapFactory - Interface in org.apache.druid.collections.bitmap
 
BitmapIndex - Interface in org.apache.druid.segment.column
 
BitmapIndexColumnPartSupplier - Class in org.apache.druid.segment.serde
 
BitmapIndexColumnPartSupplier(BitmapFactory, GenericIndexed<ImmutableBitmap>, GenericIndexed<String>) - Constructor for class org.apache.druid.segment.serde.BitmapIndexColumnPartSupplier
 
BitmapIndexSelector - Interface in org.apache.druid.query.filter
 
BitmapOffset - Class in org.apache.druid.segment
 
BitmapResultFactory<T> - Interface in org.apache.druid.query
BitmapResultFactory is an abstraction that allows to record something along with preFilter bitmap construction, and emit this information as dimension(s) of query metrics.
BitmapSerde - Class in org.apache.druid.segment.data
 
BitmapSerde() - Constructor for class org.apache.druid.segment.data.BitmapSerde
 
BitmapSerde.DefaultBitmapSerdeFactory - Class in org.apache.druid.segment.data
 
BitmapSerde.LegacyBitmapSerdeFactory - Class in org.apache.druid.segment.data
 
BitmapSerdeFactory - Interface in org.apache.druid.segment.data
 
bitmapsFromIndexes(IntIterable, BitmapIndex) - Static method in class org.apache.druid.segment.filter.Filters
Transform an iterable of indexes of bitmaps to an iterable of bitmaps
BitmapValues - Interface in org.apache.druid.segment.data
Doesn't extend IntIterable to avoid accidental for-each iteration with boxing.
BitmapVectorOffset - Class in org.apache.druid.segment.vector
 
BitmapVectorOffset(int, ImmutableBitmap, int, int) - Constructor for class org.apache.druid.segment.vector.BitmapVectorOffset
 
BitSetBitmapFactory - Class in org.apache.druid.collections.bitmap
BitSetBitmapFactory implements BitmapFactory as a wrapper for java.util.BitSet
BitSetBitmapFactory() - Constructor for class org.apache.druid.collections.bitmap.BitSetBitmapFactory
 
BitSetIterator(MutableBitmap) - Constructor for class org.apache.druid.collections.IntegerSet.BitSetIterator
 
BlockLayoutColumnarDoublesSerializer - Class in org.apache.druid.segment.data
BlockLayoutColumnarDoublesSupplier - Class in org.apache.druid.segment.data
 
BlockLayoutColumnarDoublesSupplier(int, int, ByteBuffer, ByteOrder, CompressionStrategy) - Constructor for class org.apache.druid.segment.data.BlockLayoutColumnarDoublesSupplier
 
BlockLayoutColumnarFloatsSerializer - Class in org.apache.druid.segment.data
BlockLayoutColumnarFloatsSupplier - Class in org.apache.druid.segment.data
 
BlockLayoutColumnarFloatsSupplier(int, int, ByteBuffer, ByteOrder, CompressionStrategy) - Constructor for class org.apache.druid.segment.data.BlockLayoutColumnarFloatsSupplier
 
BlockLayoutColumnarLongsSerializer - Class in org.apache.druid.segment.data
BlockLayoutColumnarLongsSupplier - Class in org.apache.druid.segment.data
 
BlockLayoutColumnarLongsSupplier(int, int, ByteBuffer, ByteOrder, CompressionFactory.LongEncodingReader, CompressionStrategy) - Constructor for class org.apache.druid.segment.data.BlockLayoutColumnarLongsSupplier
 
BLOOM_DIM_FILTER_CACHE_ID - Static variable in class org.apache.druid.query.filter.DimFilterUtils
 
BLOOM_FILTER_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
BLOOM_FILTER_MERGE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
BooleanFilter - Interface in org.apache.druid.query.filter
 
BooleanValueMatcher - Class in org.apache.druid.segment.filter
 
BooleanVectorValueMatcher - Class in org.apache.druid.query.filter.vector
 
BothTrimExprMacro() - Constructor for class org.apache.druid.query.expression.TrimExprMacro.BothTrimExprMacro
 
Bound - Interface in org.apache.druid.collections.spatial.search
 
bound(String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
BoundDimFilter - Class in org.apache.druid.query.filter
 
BoundDimFilter(String, String, String, Boolean, Boolean, Boolean, ExtractionFn, StringComparator, FilterTuning) - Constructor for class org.apache.druid.query.filter.BoundDimFilter
 
BoundDimFilter(String, String, String, Boolean, Boolean, Boolean, ExtractionFn, StringComparator) - Constructor for class org.apache.druid.query.filter.BoundDimFilter
 
BoundFilter - Class in org.apache.druid.segment.filter
 
BoundFilter(BoundDimFilter) - Constructor for class org.apache.druid.segment.filter.BoundFilter
 
breadthFirstSearch(ImmutableNode, Bound) - Method in class org.apache.druid.collections.spatial.search.GutmanSearchStrategy
 
breadthFirstSearch(Iterable<ImmutableNode>, Bound, int) - Method in class org.apache.druid.collections.spatial.search.GutmanSearchStrategy
 
breaks - Variable in class org.apache.druid.query.aggregation.Histogram
 
breaks - Variable in class org.apache.druid.query.aggregation.HistogramVisual
 
BroadcastJoinableMMappedQueryableSegmentizerFactory - Class in org.apache.druid.segment.loading
 
BroadcastJoinableMMappedQueryableSegmentizerFactory(IndexIO, Set<String>) - Constructor for class org.apache.druid.segment.loading.BroadcastJoinableMMappedQueryableSegmentizerFactory
 
BroadcastSegmentIndexedTable - Class in org.apache.druid.segment.join.table
 
BroadcastSegmentIndexedTable(QueryableIndexSegment, Set<String>, String) - Constructor for class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
BROKER_PARALLEL_MERGE_INITIAL_YIELD_ROWS_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
BROKER_PARALLEL_MERGE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
BROKER_PARALLEL_MERGE_SMALL_BATCH_ROWS_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
BROKER_PARALLELISM - Static variable in class org.apache.druid.query.QueryContexts
 
bucketCopied(int, int, MemoryOpenHashTable, MemoryOpenHashTable) - Method in interface org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable.BucketCopyHandler
Indicates that "oldBucket" in "oldTable" was copied to "newBucket" in "newTable".
bucketEntryForOffset(int) - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
BucketExtractionFn - Class in org.apache.druid.query.extraction
 
BucketExtractionFn(Double, Double) - Constructor for class org.apache.druid.query.extraction.BucketExtractionFn
 
bucketIterator() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Iterates over all used buckets, returning bucket numbers for each one.
bucketKeyOffset() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the offset within each bucket where the key starts.
bucketMemoryPosition(int) - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the position within MemoryOpenHashTable.memory() where a particular bucket starts.
bucketSize - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
bucketSize(int, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the size of each bucket in a table.
bucketSize() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the size in bytes of each bucket.
bucketSizeWithHash - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
bucketUpdateHandler - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
bucketValueOffset() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the offset within each bucket where the value starts.
buffer - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
BUFFER_SIZE - Static variable in class org.apache.druid.segment.CompressedPools
 
BufferAggregator - Interface in org.apache.druid.query.aggregation
A BufferAggregator is an object that can aggregate metrics into a ByteBuffer.
BufferArrayGrouper - Class in org.apache.druid.query.groupby.epinephelinae
A buffer grouper for array-based aggregation.
BufferArrayGrouper(Supplier<ByteBuffer>, AggregatorAdapters, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
bufferComparator(int, StringComparator) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DictionaryBuildingStringGroupByColumnSelectorStrategy
 
bufferComparator(int, StringComparator) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
bufferComparator(int, StringComparator) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
bufferComparator(int, StringComparator) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
Return BufferComparator for values written using this strategy when limit is pushed down to segment scan.
bufferComparator(int, StringComparator) - Method in class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
bufferComparator(int, StringComparator) - Method in class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
bufferComparator(int, StringComparator) - Method in class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 
bufferComparator() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
Return an object that knows how to compare two serialized keys.
bufferComparator(boolean, boolean, int, Grouper.BufferComparator[]) - Static method in class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
 
bufferComparatorWithAggregators(AggregatorFactory[], int[]) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
When pushing down limits, it may also be necessary to compare aggregated values along with the key using the bufferComparator.
bufferComparatorWithAggregators(AggregatorFactory[], int[], DefaultLimitSpec, List<DimensionSpec>, Grouper.BufferComparator[], boolean, boolean) - Static method in class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
 
bufferGrouperMaxSize - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
BufferGrouperOffsetHeapIndexUpdater(ByteBuffer, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper.BufferGrouperOffsetHeapIndexUpdater
 
BufferHashGrouper<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
 
BufferHashGrouper(Supplier<ByteBuffer>, Grouper.KeySerde<KeyType>, AggregatorAdapters, int, float, int, boolean) - Constructor for class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
bufferSupplier - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
build() - Method in class org.apache.druid.query.cache.CacheKeyBuilder
 
build() - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
 
build() - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
build() - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
build() - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
build() - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
build() - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
build() - Method in class org.apache.druid.query.filter.DimFilter.DimFilterToStringBuilder
 
build() - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
build(GroupByQuery) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
build() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.Builder
 
build(GroupByQuery) - Method in interface org.apache.druid.query.groupby.orderby.LimitSpec
Returns a function that applies a limit to an input sequence that is assumed to be sorted on dimensions.
build(GroupByQuery) - Method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
build() - Method in class org.apache.druid.query.timeseries.TimeseriesResultBuilder
 
build() - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm.AggregatorArrayProvider
 
build() - Method in class org.apache.druid.query.topn.DimValHolder.Builder
 
build() - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
build() - Method in class org.apache.druid.query.topn.TopNLexicographicResultBuilder
 
build() - Method in interface org.apache.druid.query.topn.TopNMetricSpecBuilder
 
build() - Method in class org.apache.druid.query.topn.TopNNumericResultBuilder
 
build() - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
build() - Method in interface org.apache.druid.query.topn.TopNResultBuilder
 
build() - Method in class org.apache.druid.segment.column.ColumnBuilder
 
build() - Method in class org.apache.druid.segment.column.ColumnDescriptor.Builder
 
build() - Method in class org.apache.druid.segment.column.RowSignature.Builder
 
build() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
build() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
 
build(DataSource, JoinConditionAnalysis) - Method in interface org.apache.druid.segment.join.JoinableFactory
Create a Joinable object.
build(DataSource, JoinConditionAnalysis) - Method in class org.apache.druid.segment.join.MapJoinableFactory
 
build(Granularity) - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder
 
build() - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde.SerializerBuilder
 
build() - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
 
build() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde.SerializerBuilder
 
build() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2.SerializerBuilder
 
build() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde.SerializerBuilder
 
build() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2.SerializerBuilder
 
build() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde.SerializerBuilder
 
build() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2.SerializerBuilder
 
BUILD_SEGMENTS - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
buildAggregator(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
buildAggregator(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
buildAggregator(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
buildAggregator(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
buildAggregator(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
buildAggregator(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
buildAggregator(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
buildAggregator(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
buildAggregator(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
buildAggregator(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
buildAggregator(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
buildAggregator(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
buildBufferAggregator(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
buildBufferAggregator(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
buildBufferAggregator(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
buildBufferAggregator(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
buildBufferAggregator(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
buildBufferAggregator(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
buildBufferAggregator(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
buildBufferAggregator(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
buildBufferAggregator(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
buildBufferAggregator(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
buildBufferAggregator(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
buildBufferAggregator(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
builder - Variable in class org.apache.druid.query.DefaultQueryMetrics
 
builder() - Static method in class org.apache.druid.query.groupby.GroupByQuery
 
Builder() - Constructor for class org.apache.druid.query.groupby.GroupByQuery.Builder
 
Builder(GroupByQuery) - Constructor for class org.apache.druid.query.groupby.GroupByQuery.Builder
 
Builder(GroupByQuery.Builder) - Constructor for class org.apache.druid.query.groupby.GroupByQuery.Builder
 
builder() - Static method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
Builder() - Constructor for class org.apache.druid.query.topn.DimValHolder.Builder
 
builder() - Static method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
 
Builder() - Constructor for class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
builder() - Static method in class org.apache.druid.segment.column.ColumnDescriptor
 
Builder() - Constructor for class org.apache.druid.segment.column.ColumnDescriptor.Builder
 
builder() - Static method in class org.apache.druid.segment.column.RowSignature
 
Builder() - Constructor for class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
Builder() - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
Builder(JoinFilterPreAnalysisKey, List<VirtualColumn>) - Constructor for class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
 
buildOffheap(NonBlockingPool<ByteBuffer>) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
buildOnheap() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
buildResult(DateTime, DateTime) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
buildResult(DateTime, DateTime, DateTime) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
buildVectorized(Expr.VectorInputBindingTypes) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
 
buildVectorized(int) - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder
 
builtInFactories() - Static method in interface org.apache.druid.segment.writeout.SegmentWriteOutMediumFactory
 
BySegmentQueryRunner<T> - Class in org.apache.druid.query
Query runner that wraps a base single-segment query runner, and wraps its results in a BySegmentResultValueClass object if the "bySegment" query context parameter is set.
BySegmentQueryRunner(SegmentId, DateTime, QueryRunner<T>) - Constructor for class org.apache.druid.query.BySegmentQueryRunner
 
BySegmentResultValue<T> - Interface in org.apache.druid.query
 
BySegmentResultValueClass<T> - Class in org.apache.druid.query
 
BySegmentResultValueClass(List<T>, String, Interval) - Constructor for class org.apache.druid.query.BySegmentResultValueClass
 
BySegmentSearchResultValue - Class in org.apache.druid.query.search
 
BySegmentSearchResultValue(List<Result<SearchResultValue>>, String, Interval) - Constructor for class org.apache.druid.query.search.BySegmentSearchResultValue
 
BySegmentSkippingQueryRunner<T> - Class in org.apache.druid.query
 
BySegmentSkippingQueryRunner(QueryRunner<T>) - Constructor for class org.apache.druid.query.BySegmentSkippingQueryRunner
 
BySegmentTopNResultValue - Class in org.apache.druid.query.topn
 
BySegmentTopNResultValue(List<Result<TopNResultValue>>, String, Interval) - Constructor for class org.apache.druid.query.topn.BySegmentTopNResultValue
 
BYTE_ORDER - Static variable in class org.apache.druid.segment.IndexIO
 
ByteBufferHashTable - Class in org.apache.druid.query.groupby.epinephelinae
 
ByteBufferHashTable(float, int, int, ByteBuffer, int, int, ByteBufferHashTable.BucketUpdateHandler) - Constructor for class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
ByteBufferHashTable.BucketUpdateHandler - Interface in org.apache.druid.query.groupby.epinephelinae
 
ByteBufferIntList - Class in org.apache.druid.query.groupby.epinephelinae
 
ByteBufferIntList(ByteBuffer, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.ByteBufferIntList
 
ByteBufferMinMaxOffsetHeap - Class in org.apache.druid.query.groupby.epinephelinae
ByteBuffer-based implementation of the min-max heap developed by Atkinson, et al.
ByteBufferMinMaxOffsetHeap(ByteBuffer, int, Comparator<Integer>, LimitedBufferHashGrouper.BufferGrouperOffsetHeapIndexUpdater) - Constructor for class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
ByteBufferWriteOutBytes - Class in org.apache.druid.segment.writeout
 
ByteBufferWriter<T> - Class in org.apache.druid.segment.data
 
ByteBufferWriter(SegmentWriteOutMedium, ObjectStrategy<T>) - Constructor for class org.apache.druid.segment.data.ByteBufferWriter
 

C

CACHE_TYPE_ID_BUCKET - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_CASCADE - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_EXPRESSION - Static variable in class org.apache.druid.segment.virtual.VirtualColumnCacheHelper
 
CACHE_TYPE_ID_IDENTITY - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_JAVASCRIPT - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_LOOKUP - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_LOWER - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_MAP - Static variable in class org.apache.druid.segment.virtual.VirtualColumnCacheHelper
 
CACHE_TYPE_ID_MATCHING_DIM - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_REGEX - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_SEARCH_QUERY - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_STRING_FORMAT - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_STRLEN - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_SUBSTRING - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_TIME_DIM - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_TIME_FORMAT - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_UPPER - Static variable in class org.apache.druid.query.extraction.ExtractionCacheHelper
 
CACHE_TYPE_ID_USER_DEFINED - Static variable in class org.apache.druid.segment.virtual.VirtualColumnCacheHelper
 
CacheKeyBuilder - Class in org.apache.druid.query.cache
CacheKeyBuilder is a tool for easily generating cache keys of Cacheable objects.
CacheKeyBuilder(byte) - Constructor for class org.apache.druid.query.cache.CacheKeyBuilder
 
CacheStrategy<T,CacheType,QueryType extends Query<T>> - Interface in org.apache.druid.query
Handles caching-related tasks for a particular query type.
CacheStrategy.AddToResultFunction - Interface in org.apache.druid.query
 
CachingIndexed<T> - Class in org.apache.druid.segment.data
 
CachingIndexed(GenericIndexed<T>, int) - Constructor for class org.apache.druid.segment.data.CachingIndexed
Creates a CachingIndexed wrapping the given GenericIndexed with a value lookup cache CachingIndexed objects are not thread safe and should only be used by a single thread at a time.
CalciteCnfHelper - Class in org.apache.druid.segment.filter.cnf
All functions in this class were basically adopted from Apache Calcite and modified to use them in Druid.
calculateTableArenaSizeWithFixedAdditionalSize(int, int, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
calculateTableArenaSizeWithPerBucketAdditionalSize(int, int, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
CalledFromHotLoop - Annotation Type in org.apache.druid.query.monomorphicprocessing
Annotation for methods, which are called from hot loops during query processing.
canAllowNewBucket() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
canAppendRow() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
canAppendRow() - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
canAppendRow() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
canApplyExtractionInPost(TopNQuery) - Static method in class org.apache.druid.query.topn.TopNQueryEngine
ExtractionFn which are one to one may have their execution deferred until as late as possible, since the which value is used as the grouping key itself doesn't particularly matter.
canBeOptimizedUnordered() - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
canBeOptimizedUnordered() - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
canBeOptimizedUnordered() - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
canBeOptimizedUnordered() - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
canBeOptimizedUnordered() - Method in interface org.apache.druid.query.topn.TopNMetricSpec
 
canHashJoin() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
Returns whether this condition can be satisfied using a hashtable made from the right-hand side.
canInsertNewBucket() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns whether this table can accept a new bucket.
canIterate() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
canIterate() - Method in class org.apache.druid.query.lookup.LookupExtractor
Returns true if this lookup extractor's LookupExtractor.iterable() method will return a valid iterator.
canMapOverDictionary(Expr.BindingAnalysis, ColumnCapabilities.Capable) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
Returns whether an expression can be applied to unique values of a particular column (like those in a dictionary) rather than being applied to each row individually.
canPerformSubquery(Query<?>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
canPerformSubquery(Query<?>) - Method in class org.apache.druid.query.QueryToolChest
Returns whether this toolchest is able to handle the provided subquery.
canPushDownLimit(ColumnSelectorFactory, String) - Static method in class org.apache.druid.query.groupby.epinephelinae.GroupByQueryEngineV2
check if a column will operate correctly with LimitedBufferHashGrouper for query limit pushdown
canSkip() - Method in interface org.apache.druid.segment.DimensionMerger
Return true if this dimension's data does not need to be written to the segment.
canSkip() - Method in class org.apache.druid.segment.NumericDimensionMergerV9
 
canSkip() - Method in class org.apache.druid.segment.StringDimensionMergerV9
 
canSkipAggregate(int) - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
Called to check if it's possible to skip aggregation for a row.
canSkipAggregate(int) - Method in class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
canSkipAggregate(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Returns whether or not this aggregation class supports vectorization.
canVectorize(ColumnInspector, String, String, Supplier<Expr>) - Static method in class org.apache.druid.query.aggregation.AggregatorUtil
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
canVectorize() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
canVectorize() - Method in interface org.apache.druid.query.dimension.DimensionSpec
canVectorize(Expr.InputBindingTypes) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
 
canVectorize(GroupByQuery, StorageAdapter, Filter) - Static method in class org.apache.druid.query.groupby.epinephelinae.vector.VectorGroupByEngine
 
canVectorize(Filter, VirtualColumns, boolean) - Method in interface org.apache.druid.segment.CursorFactory
Returns true if the provided combination of parameters can be handled by "makeVectorCursor".
canVectorize(Filter, VirtualColumns, boolean) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
canVectorize(ColumnInspector) - Method in interface org.apache.druid.segment.VirtualColumn
 
canVectorize(ColumnInspector) - Method in class org.apache.druid.segment.VirtualColumns
 
canVectorizeDimensions(Function<String, ColumnCapabilities>, List<DimensionSpec>) - Static method in class org.apache.druid.query.groupby.epinephelinae.vector.VectorGroupByEngine
 
canVectorizeMatcher() - Method in interface org.apache.druid.query.filter.Filter
Returns true if this filter can produce a vectorized matcher from its "makeVectorMatcher" method.
canVectorizeMatcher() - Method in class org.apache.druid.query.filter.InDimFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.AndFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.BoundFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.FalseFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.LikeFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.NotFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.OrFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.SelectorFilter
 
canVectorizeMatcher() - Method in class org.apache.druid.segment.filter.TrueFilter
 
capabilities(String) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
capabilities(ColumnInspector, String) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
capabilities(String) - Method in interface org.apache.druid.segment.VirtualColumn
Deprecated.
capabilities(ColumnInspector, String) - Method in interface org.apache.druid.segment.VirtualColumn
Return the ColumnCapabilities which best describe the optimal selector to read from this virtual column.
CARD_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
CARDINALITY_AGG_NULL_STRING - Static variable in class org.apache.druid.query.aggregation.cardinality.types.StringCardinalityAggregatorColumnSelectorStrategy
 
CARDINALITY_AGG_SEPARATOR - Static variable in class org.apache.druid.query.aggregation.cardinality.types.StringCardinalityAggregatorColumnSelectorStrategy
 
CARDINALITY_UNKNOWN - Static variable in class org.apache.druid.query.topn.TopNParams
 
CARDINALITY_UNKNOWN - Static variable in interface org.apache.druid.segment.DimensionDictionarySelector
 
CARDINALITY_UNKNOWN - Static variable in interface org.apache.druid.segment.join.Joinable
 
CardinalityAggregator - Class in org.apache.druid.query.aggregation.cardinality
 
CardinalityAggregatorColumnSelectorStrategy<ValueSelectorType> - Interface in org.apache.druid.query.aggregation.cardinality.types
 
CardinalityAggregatorColumnSelectorStrategyFactory - Class in org.apache.druid.query.aggregation.cardinality.types
 
CardinalityAggregatorColumnSelectorStrategyFactory() - Constructor for class org.apache.druid.query.aggregation.cardinality.types.CardinalityAggregatorColumnSelectorStrategyFactory
 
CardinalityAggregatorFactory - Class in org.apache.druid.query.aggregation.cardinality
 
CardinalityAggregatorFactory(String, List<String>, List<DimensionSpec>, boolean, boolean) - Constructor for class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
CardinalityAggregatorFactory(String, List<DimensionSpec>, boolean) - Constructor for class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
CardinalityBufferAggregator - Class in org.apache.druid.query.aggregation.cardinality
 
CascadeExtractionFn - Class in org.apache.druid.query.extraction
 
CascadeExtractionFn(ExtractionFn[]) - Constructor for class org.apache.druid.query.extraction.CascadeExtractionFn
 
CaseInsensitiveContainsExprMacro - Class in org.apache.druid.query.expression
This class implements a function that checks if one string contains another string.
CaseInsensitiveContainsExprMacro() - Constructor for class org.apache.druid.query.expression.CaseInsensitiveContainsExprMacro
 
ChainedExecutionQueryRunner<T> - Class in org.apache.druid.query
A QueryRunner that combines a list of other QueryRunners and executes them in parallel on an executor.
ChainedExecutionQueryRunner(ExecutorService, QueryWatcher, QueryRunner<T>...) - Constructor for class org.apache.druid.query.ChainedExecutionQueryRunner
 
ChainedExecutionQueryRunner(ExecutorService, QueryWatcher, Iterable<QueryRunner<T>>) - Constructor for class org.apache.druid.query.ChainedExecutionQueryRunner
 
checkFileSize(File) - Static method in class org.apache.druid.segment.IndexIO
 
checkInterrupted() - Static method in class org.apache.druid.query.BaseQuery
 
checkModifiedFromOwnerThread() - Method in class org.apache.druid.query.DefaultQueryMetrics
 
checkPrefixesForDuplicatesAndShadowing(List<String>) - Static method in class org.apache.druid.segment.join.Joinables
Check if any prefixes in the provided list duplicate or shadow each other.
checkRowIndexAndAddValueToGroupingKey(int, Object, int, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
checkRowIndexAndAddValueToGroupingKey(int, Object, int, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
checkRowIndexAndAddValueToGroupingKey(int, Object, int, ByteBuffer) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
If rowValIdx is less than the size of rowObj (haven't handled all of the row values): First, read the value at rowValIdx from a rowObj and write that value to the keyBuffer at keyBufferPosition.
checkRowIndexAndAddValueToGroupingKey(int, Object, int, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
checkRowIndexAndAddValueToGroupingKey(int, Object, int, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
checkRowIndexAndAddValueToGroupingKey(int, Object, int, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 
checkUnsortedEncodedKeyComponentsEqual(EncodedKeyComponentType, EncodedKeyComponentType) - Method in interface org.apache.druid.segment.DimensionIndexer
Check if two row value arrays from Row keys are equal.
checkUnsortedEncodedKeyComponentsEqual(Double, Double) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
checkUnsortedEncodedKeyComponentsEqual(Float, Float) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
checkUnsortedEncodedKeyComponentsEqual(Long, Long) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
checkUnsortedEncodedKeyComponentsEqual(int[], int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
classOfObject() - Method in class org.apache.druid.query.aggregation.cardinality.HyperLogLogCollectorAggregateCombiner
 
classOfObject() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregateCombiner
 
classOfObject() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregateCombiner
 
classOfObject() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
classOfObject() - Method in interface org.apache.druid.segment.BaseObjectColumnValueSelector
 
classOfObject() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
classOfObject() - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
classOfObject() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
 
classOfObject() - Method in interface org.apache.druid.segment.DoubleColumnSelector
Deprecated.
This method is marked as deprecated in DoubleColumnSelector to minimize the probability of accidental calling. "Polymorphism" of DoubleColumnSelector should be used only when operating on ColumnValueSelector objects.
classOfObject() - Method in interface org.apache.druid.segment.FloatColumnSelector
Deprecated.
This method is marked as deprecated in FloatColumnSelector to minimize the probability of accidental calling. "Polymorphism" of FloatColumnSelector should be used only when operating on ColumnValueSelector objects.
classOfObject() - Method in class org.apache.druid.segment.join.PossiblyNullColumnValueSelector
 
classOfObject() - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
classOfObject() - Method in class org.apache.druid.segment.join.table.IndexedTableColumnValueSelector
 
classOfObject() - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
classOfObject() - Method in interface org.apache.druid.segment.LongColumnSelector
Deprecated.
This method is marked as deprecated in LongColumnSelector to minimize the probability of accidental calling. "Polymorphism" of LongColumnSelector should be used only when operating on ColumnValueSelector objects.
classOfObject() - Method in class org.apache.druid.segment.NilColumnValueSelector
Returns Object.class.
classOfObject() - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
classOfObject() - Method in class org.apache.druid.segment.selector.settable.SettableObjectColumnValueSelector
 
classOfObject() - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
classOfObject() - Method in class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
 
classOfObject() - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
classOfObject() - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
 
classOfObject() - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
 
classOfObject() - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
cleanup(TopNParams) - Method in class org.apache.druid.query.topn.AggregateTopNMetricFirstAlgorithm
 
cleanup(TopNParams) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
cleanup(PooledTopNAlgorithm.PooledTopNParams) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
cleanup(TopNParams) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
cleanup(Parameters) - Method in interface org.apache.druid.query.topn.TopNAlgorithm
 
clear() - Method in interface org.apache.druid.collections.bitmap.MutableBitmap
Empties the content of this bitmap.
clear() - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
clear() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
clear() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
clear() - Method in class org.apache.druid.collections.IntegerSet
 
clear() - Method in class org.apache.druid.collections.spatial.Node
 
clear() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Clear the table, resetting size to zero.
clearEncodingFlag(byte) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
clone() - Method in class org.apache.druid.collections.bitmap.BatchIteratorAdapter
 
clone() - Method in class org.apache.druid.collections.bitmap.PeekableIteratorAdapter
 
clone() - Method in class org.apache.druid.segment.BitmapOffset
 
clone() - Method in class org.apache.druid.segment.data.Offset
 
clone() - Method in class org.apache.druid.segment.FilteredOffset
clone() is not supported by FilteredOffset because it's not possible to clone FilteredOffset.filterMatcher, and while re-creating filterMatcher could be not very cheap for some implementations of Filter.
clone() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.AscendingTimestampCheckingOffset
 
clone() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.DescendingTimestampCheckingOffset
 
clone() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset
 
clone() - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
clone() - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
cloneBitSet() - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
close() - Method in interface org.apache.druid.query.aggregation.Aggregator
 
close() - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Close all of our aggregators.
close() - Method in class org.apache.druid.query.aggregation.any.NumericAnyAggregator
 
close() - Method in class org.apache.druid.query.aggregation.any.NumericAnyBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.any.NumericAnyVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.any.NumericNilVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
 
close() - Method in class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.any.StringAnyVectorAggregator
 
close() - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Release any resources used by the aggregator
close() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
 
close() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.CountAggregator
 
close() - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.CountVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
 
close() - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregator
 
close() - Method in class org.apache.druid.query.aggregation.DoubleMaxVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregator
 
close() - Method in class org.apache.druid.query.aggregation.DoubleMinVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregator
 
close() - Method in class org.apache.druid.query.aggregation.DoubleSumVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FilteredVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.first.NumericFirstAggregator
 
close() - Method in class org.apache.druid.query.aggregation.first.NumericFirstBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
close() - Method in class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FloatMaxVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FloatMinAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FloatMinVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FloatSumAggregator
 
close() - Method in class org.apache.druid.query.aggregation.FloatSumVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.HistogramAggregator
 
close() - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
 
close() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
 
close() - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.last.NumericLastAggregator
 
close() - Method in class org.apache.druid.query.aggregation.last.NumericLastBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregator
 
close() - Method in class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.LongMaxAggregator
 
close() - Method in class org.apache.druid.query.aggregation.LongMaxVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.LongMinAggregator
 
close() - Method in class org.apache.druid.query.aggregation.LongMinVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.LongSumAggregator
 
close() - Method in class org.apache.druid.query.aggregation.LongSumVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
 
close() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.NoopAggregator
 
close() - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.NoopVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
 
close() - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.NullableNumericVectorAggregator
 
close() - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.SimpleLongBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
close() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
close() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
close() - Method in interface org.apache.druid.query.aggregation.VectorAggregator
Release any resources used by the aggregator.
close() - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
close() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
close() - Method in class org.apache.druid.query.groupby.epinephelinae.CloseableGrouperIterator
 
close() - Method in class org.apache.druid.query.groupby.epinephelinae.ConcurrentGrouper
 
close() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
Close the grouper and release associated resources.
close() - Method in class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
 
close() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage
 
close() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
 
close() - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
 
close() - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
 
close() - Method in interface org.apache.druid.query.groupby.epinephelinae.VectorGrouper
Close the grouper and release associated resources.
close() - Method in class org.apache.druid.query.groupby.resource.GroupByQueryResource
 
close() - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
This method will be called to stop the LookupExtractor upon Druid process stop.
close() - Method in class org.apache.druid.query.scan.ScanQueryLimitRowIterator
 
close() - Method in interface org.apache.druid.segment.column.ComplexColumn
Close and release any resources associated with this column.
close() - Method in class org.apache.druid.segment.column.DoublesColumn
 
close() - Method in class org.apache.druid.segment.column.FloatsColumn
 
close() - Method in class org.apache.druid.segment.column.GenericIndexedBasedComplexColumn
 
close() - Method in class org.apache.druid.segment.column.LongsColumn
 
close() - Method in interface org.apache.druid.segment.column.NumericColumn
 
close() - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
close() - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
close() - Method in class org.apache.druid.segment.data.CachingIndexed
 
close() - Method in interface org.apache.druid.segment.data.ColumnarDoubles
 
close() - Method in interface org.apache.druid.segment.data.ColumnarFloats
 
close() - Method in interface org.apache.druid.segment.data.ColumnarLongs
 
close() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
 
close() - Method in class org.apache.druid.segment.data.GenericIndexed
 
close() - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
close() - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
close() - Method in class org.apache.druid.segment.ForwardingRowIterator
 
close() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
close() - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
NOTE: This is NOT thread-safe with add...
close() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
Clear out maps to allow GC NOTE: This is NOT thread-safe with add...
close() - Method in class org.apache.druid.segment.IncrementalIndexSegment
 
close() - Method in class org.apache.druid.segment.IndexMerger.DictionaryMergeIterator
 
close() - Method in class org.apache.druid.segment.join.HashJoinSegment
 
close() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
close() - Method in interface org.apache.druid.segment.join.table.IndexedTable.Reader
 
close() - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
close() - Method in interface org.apache.druid.segment.QueryableIndex
The close method shouldn't actually be here as this is nasty.
close() - Method in class org.apache.druid.segment.QueryableIndexSegment
 
close() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
 
close() - Method in class org.apache.druid.segment.RowBasedSegment
 
close() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
close() - Method in interface org.apache.druid.segment.TimeAndDimsIterator
Closes any resources, associated with this iterator.
close() - Method in interface org.apache.druid.segment.vector.VectorCursor
Close the cursor and release its resources.
close() - Method in class org.apache.druid.segment.writeout.OffHeapMemorySegmentWriteOutMedium
 
close() - Method in class org.apache.druid.segment.writeout.OnHeapMemorySegmentWriteOutMedium
 
close() - Method in class org.apache.druid.segment.writeout.TmpFileSegmentWriteOutMedium
 
close() - Method in class org.apache.druid.segment.writeout.WriteOutBytes
Deprecated.
does nothing.
CloseableGrouperIterator<KeyType,T> - Class in org.apache.druid.query.groupby.epinephelinae
 
CloseableGrouperIterator(CloseableIterator<Grouper.Entry<KeyType>>, Function<Grouper.Entry<KeyType>, T>, Closeable) - Constructor for class org.apache.druid.query.groupby.epinephelinae.CloseableGrouperIterator
 
CloseableIndexed<T> - Interface in org.apache.druid.segment.data
 
closeAggregators(DimValAggregateStore) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
closeAggregators(TopNColumnAggregatesProcessor) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
closeAggregators(BufferAggregator[]) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
closeAggregators(Map<Comparable<?>, Aggregator[]>) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
closeAggregators() - Method in class org.apache.druid.query.topn.types.NullableNumericTopNColumnAggregatesProcessor
 
closeAggregators() - Method in class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
 
closeAggregators() - Method in interface org.apache.druid.query.topn.types.TopNColumnAggregatesProcessor
Closes all on heap Aggregator associated withe the aggregates processor
coerceEvalToSelectorObject(ExprEval) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
Coerces ExprEval value back to selector friendly List if the evaluated expression result is an array type
coerceListToArray(List<?>) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
Selectors are not consistent in treatment of null, [], and [null], so coerce [] to [null]
coerceUnknownToBoolean(boolean) - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
ColumnAnalysis - Class in org.apache.druid.query.metadata.metadata
 
ColumnAnalysis(String, boolean, boolean, long, Integer, Comparable, Comparable, String) - Constructor for class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
ColumnarDoubles - Interface in org.apache.druid.segment.data
Resource that provides random access to a packed array of primitive doubles.
ColumnarDoublesSerializer - Interface in org.apache.druid.segment.data
Serializer that produces ColumnarDoubles.
ColumnarFloats - Interface in org.apache.druid.segment.data
Resource that provides random access to a packed array of primitive floats.
ColumnarFloatsSerializer - Interface in org.apache.druid.segment.data
Serializer that produces ColumnarFloats.
ColumnarInts - Interface in org.apache.druid.segment.data
Resource that provides random access to a packed array of primitive int values.
ColumnarIntsSerializer - Interface in org.apache.druid.segment.data
Serializer that produces either ColumnarInts or ColumnarMultiInts.
ColumnarLongs - Interface in org.apache.druid.segment.data
Resource that provides random access to a packed array of primitive longs.
ColumnarLongsSerializer - Interface in org.apache.druid.segment.data
Serializer that produces ColumnarLongs.
ColumnarMultiInts - Interface in org.apache.druid.segment.data
Resource that provides random access to a packed array of short arrays of ints (IndexedInts).
ColumnarMultiIntsSerializer - Class in org.apache.druid.segment.data
Serializer that produces ColumnarMultiInts.
ColumnarMultiIntsSerializer() - Constructor for class org.apache.druid.segment.data.ColumnarMultiIntsSerializer
 
ColumnBuilder - Class in org.apache.druid.segment.column
 
ColumnBuilder() - Constructor for class org.apache.druid.segment.column.ColumnBuilder
 
columnCacheSizeBytes() - Method in class org.apache.druid.query.DruidProcessingConfig
 
columnCacheSizeBytes() - Method in interface org.apache.druid.segment.column.ColumnConfig
 
ColumnCapabilities - Interface in org.apache.druid.segment.column
This interface is used to expose information about columns that is interesting to know for all matters dealing with reading from columns, including query planning and optimization, creating readers to merge segments at ingestion time, and probably nearly anything else you can imagine.
ColumnCapabilities.Capable - Enum in org.apache.druid.segment.column
 
ColumnCapabilities.CoercionLogic - Interface in org.apache.druid.segment.column
This interface define the shape of a mechnism to allow for bespoke coercion of ColumnCapabilities.Capable.UNKNOWN into ColumnCapabilities.Capable.TRUE or ColumnCapabilities.Capable.FALSE for each ColumnCapabilities.Capable of a ColumnCapabilities, as is appropriate for the situation of the caller.
ColumnCapabilitiesImpl - Class in org.apache.druid.segment.column
 
ColumnCapabilitiesImpl() - Constructor for class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
ColumnCapacityExceededException - Exception in org.apache.druid.segment.data
 
ColumnCapacityExceededException(String) - Constructor for exception org.apache.druid.segment.data.ColumnCapacityExceededException
 
ColumnComparisonDimFilter - Class in org.apache.druid.query.filter
 
ColumnComparisonDimFilter(List<DimensionSpec>) - Constructor for class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
ColumnComparisonFilter - Class in org.apache.druid.segment.filter
 
ColumnComparisonFilter(List<DimensionSpec>) - Constructor for class org.apache.druid.segment.filter.ColumnComparisonFilter
 
ColumnConfig - Interface in org.apache.druid.segment.column
 
ColumnDescriptor - Class in org.apache.druid.segment.column
 
ColumnDescriptor(ValueType, boolean, List<ColumnPartSerde>) - Constructor for class org.apache.druid.segment.column.ColumnDescriptor
 
ColumnDescriptor.Builder - Class in org.apache.druid.segment.column
 
columnFunction(String) - Method in interface org.apache.druid.segment.RowAdapter
Returns a function that retrieves the value for column "columnName" from rows.
ColumnHolder - Interface in org.apache.druid.segment.column
 
ColumnIncluderator - Interface in org.apache.druid.query.metadata.metadata
 
columnIndex(int) - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
columnIndex(int) - Method in interface org.apache.druid.segment.join.table.IndexedTable
Returns the index for a particular column.
columnIndex(int) - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
 
columnIndex(int) - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
ColumnInspector - Interface in org.apache.druid.segment
 
ColumnPartSerde - Interface in org.apache.druid.segment.serde
 
ColumnPartSerde.Deserializer - Interface in org.apache.druid.segment.serde
 
ColumnProcessorFactory<T> - Interface in org.apache.druid.segment
Class that encapsulates knowledge about how to create "column processors", which are...
ColumnProcessors - Class in org.apache.druid.segment
Creates "column processors", which are objects that wrap a single input column and provide some functionality on top of it.
ColumnProcessors() - Constructor for class org.apache.druid.segment.ColumnProcessors
 
columnReader(int) - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
columnReader(int) - Method in interface org.apache.druid.segment.join.table.IndexedTable
Returns a reader for a particular column.
columnReader(int) - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
 
columnReader(int) - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
columns(List<String>) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
columns(String...) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
ColumnSelector - Interface in org.apache.druid.segment
 
ColumnSelectorBitmapIndexSelector - Class in org.apache.druid.segment
 
ColumnSelectorBitmapIndexSelector(BitmapFactory, VirtualColumns, ColumnSelector) - Constructor for class org.apache.druid.segment.ColumnSelectorBitmapIndexSelector
 
ColumnSelectorFactory - Interface in org.apache.druid.segment
Factory class for MetricSelectors
ColumnSelectorPlus<ColumnSelectorStrategyClass extends ColumnSelectorStrategy> - Class in org.apache.druid.query
A grouping of various related objects used during query processing for a single dimension, used for convenience.
ColumnSelectorPlus(String, String, ColumnSelectorStrategyClass, ColumnValueSelector) - Constructor for class org.apache.druid.query.ColumnSelectorPlus
 
ColumnSelectorStrategy - Interface in org.apache.druid.query.dimension
Base type for strategy objects that handle value type operations pertaining to a specific query type
ColumnSelectorStrategyFactory<ColumnSelectorStrategyClass extends ColumnSelectorStrategy> - Interface in org.apache.druid.query.dimension
 
ColumnValueGenerator - Class in org.apache.druid.segment.generator
 
ColumnValueGenerator(GeneratorColumnSchema, long) - Constructor for class org.apache.druid.segment.generator.ColumnValueGenerator
 
columnValueSelector(ColumnValueSelector) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
columnValueSelector(ColumnValueSelector) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
This method is called exactly once with the columnValueSelector object of each cursor, processed for the query.
ColumnValueSelector<T> - Interface in org.apache.druid.segment
Base type for interfaces that manage column value selection, e.g.
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
combine(Object, Object) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
combine(List<? extends CloseableIterator<Grouper.Entry<KeyType>>>, List<String>) - Method in class org.apache.druid.query.groupby.epinephelinae.ParallelCombiner
Build a combining tree for the input iterators which combine input entries asynchronously.
COMPARATOR - Static variable in class org.apache.druid.query.aggregation.DoubleSumAggregator
 
COMPARATOR - Static variable in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
COMPARATOR - Static variable in class org.apache.druid.query.topn.AlphaNumericTopNMetricSpec
 
compare(ByteBuffer, ByteBuffer, int, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.BufferComparator
 
compare(String, String) - Method in class org.apache.druid.query.ordering.StringComparators.AlphanumericComparator
 
compare(String, String) - Method in class org.apache.druid.query.ordering.StringComparators.LexicographicComparator
 
compare(String, String) - Method in class org.apache.druid.query.ordering.StringComparators.NumericComparator
 
compare(String, String) - Method in class org.apache.druid.query.ordering.StringComparators.StrlenComparator
 
compare(String, String) - Method in class org.apache.druid.query.ordering.StringComparators.VersionComparator
 
compare(Result<T>, Result<T>) - Method in class org.apache.druid.query.ResultGranularTimestampComparator
 
compare(ScanResultValue, ScanResultValue) - Method in class org.apache.druid.query.scan.ScanResultValueTimestampComparator
 
compare(ResourceHolder<ByteBuffer>, ResourceHolder<ByteBuffer>) - Method in class org.apache.druid.segment.data.DecompressingByteBufferObjectStrategy
 
compare(ImmutableRTree, ImmutableRTree) - Method in class org.apache.druid.segment.data.ImmutableRTreeObjectStrategy
 
compareObjectsAsType(Object, Object, ValueType) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
compareTo(ImmutableRTree) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
 
compareTo(SegmentAnalysis) - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
compareTo(Result<T>) - Method in class org.apache.druid.query.Result
 
compareTo(ScanResultValue) - Method in class org.apache.druid.query.scan.ScanResultValue
 
compareTo(SearchHit) - Method in class org.apache.druid.query.search.SearchHit
 
compareTo(VSizeColumnarInts) - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
compareTo(TimeAndDimsPointer) - Method in class org.apache.druid.segment.TimeAndDimsPointer
Compares time column value and dimension column values, but not metric column values.
compareTo(Row) - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
compareUnsortedEncodedKeyComponents(EncodedKeyComponentType, EncodedKeyComponentType) - Method in interface org.apache.druid.segment.DimensionIndexer
Compares the row values for this DimensionIndexer's dimension from a Row key.
compareUnsortedEncodedKeyComponents(Double, Double) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
compareUnsortedEncodedKeyComponents(Float, Float) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
compareUnsortedEncodedKeyComponents(Long, Long) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
compareUnsortedEncodedKeyComponents(int[], int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
complement(ImmutableBitmap, int) - Method in interface org.apache.druid.collections.bitmap.BitmapFactory
 
complement(ImmutableBitmap, int) - Method in class org.apache.druid.collections.bitmap.BitSetBitmapFactory
 
complement(ImmutableBitmap, int) - Method in class org.apache.druid.collections.bitmap.ConciseBitmapFactory
 
complement(ImmutableBitmap, int) - Method in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
complement(T, int) - Method in interface org.apache.druid.query.BitmapResultFactory
Delegates to BitmapFactory.complement(ImmutableBitmap, int) on the wrapped bitmap, and returns a bitmap result wrapping the resulting complement ImmutableBitmap.
complement(ImmutableBitmap, int) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
ComplexColumn - Interface in org.apache.druid.segment.column
This interface represents a complex column and can be implemented by druid extension writer of a custom column with arbitrary serialization instead of a custom column that serializes rows of objects serialized using GenericIndexed class which is default implementation of "writeToXXX" methods in ComplexColumnSerializer.
ComplexColumnPartSerde - Class in org.apache.druid.segment.serde
 
ComplexColumnPartSerde.SerializerBuilder - Class in org.apache.druid.segment.serde
 
ComplexColumnPartSupplier - Class in org.apache.druid.segment.serde
 
ComplexColumnPartSupplier(String, GenericIndexed<?>) - Constructor for class org.apache.druid.segment.serde.ComplexColumnPartSupplier
 
ComplexColumnSerializer<T> - Class in org.apache.druid.segment.serde
 
ComplexMetricExtractor<T> - Interface in org.apache.druid.segment.serde
 
ComplexMetrics - Class in org.apache.druid.segment.serde
ComplexMetrics houses a mapping of serde names to affiliated ComplexMetricSerde objects.
ComplexMetrics() - Constructor for class org.apache.druid.segment.serde.ComplexMetrics
 
ComplexMetricSerde - Class in org.apache.druid.segment.serde
 
ComplexMetricSerde() - Constructor for class org.apache.druid.segment.serde.ComplexMetricSerde
 
composeConjunction(Iterable<? extends Filter>) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
composeConjunction(Iterable<? extends Filter>, boolean) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
Converts a collection of expressions into an AND.
composeDisjunction(Iterable<? extends Filter>) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
Converts a collection of expressions into an OR.
composeDisjunction(Iterable<? extends Filter>, boolean) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
Converts a collection of expressions into an OR, optionally returning null if the list is empty.
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.Compressor
Returns a ByteBuffer with compressed contents of in between it's position and limit.
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.LZ4Compressor
 
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.LZFCompressor
 
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.UncompressedCompressor
 
CompressedColumnarDoublesSuppliers - Class in org.apache.druid.segment.data
 
CompressedColumnarFloatsSupplier - Class in org.apache.druid.segment.data
 
CompressedColumnarIntsSerializer - Class in org.apache.druid.segment.data
Streams array of integers out in the binary format described by CompressedColumnarIntsSupplier
CompressedColumnarIntsSupplier - Class in org.apache.druid.segment.data
 
CompressedColumnarLongsSupplier - Class in org.apache.druid.segment.data
 
CompressedPools - Class in org.apache.druid.segment
 
CompressedPools() - Constructor for class org.apache.druid.segment.CompressedPools
 
CompressedVSizeColumnarIntsSerializer - Class in org.apache.druid.segment.data
Streams array of integers out in the binary format described by CompressedVSizeColumnarIntsSupplier
CompressedVSizeColumnarIntsSupplier - Class in org.apache.druid.segment.data
 
CompressedVSizeColumnarMultiIntsSupplier - Class in org.apache.druid.segment.data
Format - byte 1 - version offsets - ColumnarInts of length num of rows + 1 representing offsets of starting index of first element of each row in values index and last element equal to length of values column, the last element in the offsets represents the total length of values column.
CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts - Class in org.apache.druid.segment.data
 
CompressionFactory - Class in org.apache.druid.segment.data
Compression of metrics is done by using a combination of CompressionStrategy and Encoding(such as CompressionFactory.LongEncodingStrategy for type Long).
CompressionFactory.LongEncodingFormat - Enum in org.apache.druid.segment.data
 
CompressionFactory.LongEncodingReader - Interface in org.apache.druid.segment.data
 
CompressionFactory.LongEncodingStrategy - Enum in org.apache.druid.segment.data
The compression of decompression of encodings are separated into different enums.
CompressionFactory.LongEncodingWriter - Interface in org.apache.druid.segment.data
This writer output encoded values to the given ByteBuffer or OutputStream.
CompressionStrategy - Enum in org.apache.druid.segment.data
Compression strategy is used to compress block of bytes without knowledge of what data the bytes represents.
CompressionStrategy.Compressor - Class in org.apache.druid.segment.data
 
CompressionStrategy.Decompressor - Interface in org.apache.druid.segment.data
 
CompressionStrategy.LZ4Compressor - Class in org.apache.druid.segment.data
 
CompressionStrategy.LZ4Decompressor - Class in org.apache.druid.segment.data
 
CompressionStrategy.LZFCompressor - Class in org.apache.druid.segment.data
 
CompressionStrategy.LZFDecompressor - Class in org.apache.druid.segment.data
 
CompressionStrategy.UncompressedCompressor - Class in org.apache.druid.segment.data
 
CompressionStrategy.UncompressedDecompressor - Class in org.apache.druid.segment.data
 
Compressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.Compressor
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
compute(Map<String, Object>) - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
compute(Map<String, Object>) - Method in interface org.apache.druid.query.aggregation.PostAggregator
 
compute(long) - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector.LruEvalCache
 
compute(int) - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector.LruEvalCache
 
computeAggregatorsMap(List<AggregatorFactory>) - Static method in class org.apache.druid.query.groupby.having.HavingSpecUtil
 
computeCacheKey(QueryType) - Method in interface org.apache.druid.query.CacheStrategy
Computes the per-segment cache key for the given query.
computeEquiconditionsFromJoinableClauses() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
 
computeJoinFilterCorrelations(List<Filter>, Equiconditions, JoinableClauses, boolean, long) - Static method in class org.apache.druid.segment.join.filter.JoinFilterCorrelations
 
computeJoinFilterPreAnalysis(JoinFilterPreAnalysisKey) - Static method in class org.apache.druid.segment.join.filter.JoinFilterAnalyzer
Before making per-segment filter splitting decisions, we first do a pre-analysis step where we convert the query filter (if any) into conjunctive normal form and then determine the structure of RHS filter rewrites (if any), since this information is shared across all per-segment operations.
computeMaxMemoryFromMaxHeapSize() - Static method in class org.apache.druid.query.DruidProcessingConfig
 
computeNewLength(DimValSelector, int, int) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
Skip invalid value, calculate length to have enough valid value to process or hit the end.
computeNewLength(int[], int, int) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
computeOffset(long, DateTimeZone) - Method in class org.apache.druid.query.TimewarpOperator
Map time t into the last `period` ending within `dataInterval`
computeOverriddenContext(Map<String, Object>, Map<String, Object>) - Static method in class org.apache.druid.query.BaseQuery
 
computeOverridenContext(Map<String, Object>) - Method in class org.apache.druid.query.BaseQuery
Deprecated.
use computeOverriddenContext(getContext(), overrides)) instead. This method may be removed in the next minor or major version of Druid.
computeResultLevelCacheKey(QueryType) - Method in interface org.apache.druid.query.CacheStrategy
Computes the result-level cache key for the given query.
computeStartEnd(int) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm.BaseArrayProvider
 
ConcatQueryRunner<T> - Class in org.apache.druid.query
 
ConcatQueryRunner(Sequence<QueryRunner<T>>) - Constructor for class org.apache.druid.query.ConcatQueryRunner
 
ConciseBitmapDecisionHelper - Class in org.apache.druid.query.search
 
ConciseBitmapFactory - Class in org.apache.druid.collections.bitmap
As the name suggests, this class instantiates bitmaps of the types WrappedConciseBitmap and WrappedImmutableConciseBitmap.
ConciseBitmapFactory() - Constructor for class org.apache.druid.collections.bitmap.ConciseBitmapFactory
 
ConciseBitmapSerdeFactory - Class in org.apache.druid.segment.data
 
ConciseBitmapSerdeFactory() - Constructor for class org.apache.druid.segment.data.ConciseBitmapSerdeFactory
 
ConcisePeekableIteratorAdapter - Class in org.apache.druid.collections.bitmap
 
concurrentGet(int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
ConcurrentGrouper<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
Grouper based around a set of underlying SpillingGrouper instances.
ConcurrentGrouper(GroupByQueryConfig, Supplier<ByteBuffer>, ReferenceCountingResourceHolder<ByteBuffer>, Grouper.KeySerdeFactory<KeyType>, Grouper.KeySerdeFactory<KeyType>, ColumnSelectorFactory, AggregatorFactory[], LimitedTemporaryStorage, ObjectMapper, int, DefaultLimitSpec, boolean, ListeningExecutorService, int, boolean, long) - Constructor for class org.apache.druid.query.groupby.epinephelinae.ConcurrentGrouper
 
concurrentRemove(int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
ConcurrentResponseContext - Class in org.apache.druid.query.context
The implementation of ResponseContext with a ConcurrentHashMap as a delegate
ConcurrentResponseContext() - Constructor for class org.apache.druid.query.context.ConcurrentResponseContext
 
concurrentSet(int, Aggregator[]) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
condensedAggregators(List<AggregatorFactory>, List<PostAggregator>, String) - Static method in class org.apache.druid.query.aggregation.AggregatorUtil
 
ConfigModule - Class in org.apache.druid.guice
 
ConfigModule() - Constructor for class org.apache.druid.guice.ConfigModule
 
configure(Binder) - Method in class org.apache.druid.guice.ConfigModule
 
configure(Binder) - Method in class org.apache.druid.guice.NullHandlingModule
 
configure(Binder) - Method in class org.apache.druid.guice.PropertiesModule
 
configure(Binder) - Method in class org.apache.druid.guice.RuntimeInfoModule
 
configure(Binder) - Method in class org.apache.druid.jackson.JacksonModule
 
configure(Binder) - Method in class org.apache.druid.segment.writeout.SegmentWriteOutMediumModule
 
configureOptimizer(TopNMetricSpecBuilder<T>) - Method in class org.apache.druid.query.topn.AlphaNumericTopNMetricSpec
 
configureOptimizer(TopNMetricSpecBuilder<T>) - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
configureOptimizer(TopNMetricSpecBuilder<T>) - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
configureOptimizer(TopNMetricSpecBuilder<T>) - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
configureOptimizer(TopNMetricSpecBuilder<T>) - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
configureOptimizer(TopNMetricSpecBuilder<T>) - Method in interface org.apache.druid.query.topn.TopNMetricSpec
 
conjunctions(Filter) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
Returns a condition decomposed by AND.
CONSTANT - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
constant(String) - Static method in interface org.apache.druid.segment.DimensionSelector
 
constant(String, ExtractionFn) - Static method in interface org.apache.druid.segment.DimensionSelector
 
ConstantDimensionSelector - Class in org.apache.druid.segment
 
ConstantDimensionSelector(String) - Constructor for class org.apache.druid.segment.ConstantDimensionSelector
 
ConstantExprEvalSelector - Class in org.apache.druid.segment
 
ConstantExprEvalSelector(ExprEval) - Constructor for class org.apache.druid.segment.ConstantExprEvalSelector
 
ConstantPostAggregator - Class in org.apache.druid.query.aggregation.post
 
ConstantPostAggregator(String, Number) - Constructor for class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
ConstantValueMatcherFactory - Class in org.apache.druid.segment.filter
Creates ValueMatcher that match constants.
ConstantVectorSelectors - Class in org.apache.druid.segment.vector
 
ConstantVectorSelectors() - Constructor for class org.apache.druid.segment.vector.ConstantVectorSelectors
 
contains(Object) - Method in class org.apache.druid.collections.IntegerSet
 
contains(float[]) - Method in class org.apache.druid.collections.spatial.Node
 
contains(float[]) - Method in interface org.apache.druid.collections.spatial.search.Bound
 
contains(float[]) - Method in class org.apache.druid.collections.spatial.search.PolygonBound
 
contains(float[]) - Method in class org.apache.druid.collections.spatial.search.RadiusBound
 
contains(float[]) - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
contains(String) - Method in class org.apache.druid.segment.column.RowSignature
Returns whether this signature contains a named column.
contains(int) - Method in class org.apache.druid.segment.column.RowSignature
 
containsAll(Collection<?>) - Method in class org.apache.druid.collections.IntegerSet
 
ContainsExprMacro - Class in org.apache.druid.query.expression
This class implements a function that checks if one string contains another string.
ContainsExprMacro() - Constructor for class org.apache.druid.query.expression.ContainsExprMacro
 
ContainsSearchQuerySpec - Class in org.apache.druid.query.search
 
ContainsSearchQuerySpec(String, boolean) - Constructor for class org.apache.druid.query.search.ContainsSearchQuerySpec
 
context(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
context(Map<String, Object>) - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
 
context(Map<String, Object>) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
context(Map<String, Object>) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
context(Map<String, Object>) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
context(Map<String, Object>) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
context(Map<String, Object>) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
context(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.getContext() of the given query as dimension.
context(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
context(Map<String, Object>) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
conversions - Variable in class org.apache.druid.segment.IndexMerger.DictionaryMergeIterator
 
convert(File, File, IndexSpec) - Method in interface org.apache.druid.segment.IndexMerger
 
convert(File, File, IndexSpec) - Method in class org.apache.druid.segment.IndexMergerV9
 
converterFromTypeToType(ValueType, ValueType) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToDouble(Object) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToDouble(Object, boolean) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToFloat(Object) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToFloat(Object, boolean) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToLong(Object) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToLong(Object, boolean) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToString(Object) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToType(Object, ValueType, boolean) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertObjectToType(Object, ValueType) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
convertRowTypesToOutputTypes(List<DimensionSpec>, ResultRow, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.GroupByQueryEngineV2
 
convertSortedSegmentRowValuesToMergedRowValues(int, ColumnValueSelector) - Method in interface org.apache.druid.segment.DimensionMerger
Creates a value selector, which converts values with per-segment, _sorted order_ (see DimensionIndexer.convertUnsortedValuesToSorted(org.apache.druid.segment.ColumnValueSelector)) encoding from the given selector to their equivalent representation in the merged set of rows.
convertSortedSegmentRowValuesToMergedRowValues(int, ColumnValueSelector) - Method in class org.apache.druid.segment.NumericDimensionMergerV9
 
convertSortedSegmentRowValuesToMergedRowValues(int, ColumnValueSelector) - Method in class org.apache.druid.segment.StringDimensionMergerV9
 
convertToCnf(Filter) - Static method in class org.apache.druid.segment.filter.cnf.HiveCnfHelper
 
convertToCNFFromQueryContext(Query, Filter) - Static method in class org.apache.druid.segment.filter.Filters
 
convertUnsortedEncodedKeyComponentToActualList(EncodedKeyComponentType) - Method in interface org.apache.druid.segment.DimensionIndexer
Given a row value array from a Row key, as described in the documentation for DimensionIndexer.compareUnsortedEncodedKeyComponents(EncodedKeyComponentType, EncodedKeyComponentType), convert the unsorted encoded values to a list of actual values.
convertUnsortedEncodedKeyComponentToActualList(Double) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
convertUnsortedEncodedKeyComponentToActualList(Float) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
convertUnsortedEncodedKeyComponentToActualList(Long) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
convertUnsortedEncodedKeyComponentToActualList(int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
convertUnsortedValuesToSorted(ColumnValueSelector) - Method in interface org.apache.druid.segment.DimensionIndexer
Converts dictionary-encoded row values from unspecified (random) encoding order, to sorted encoding.
convertUnsortedValuesToSorted(ColumnValueSelector) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
convertUnsortedValuesToSorted(ColumnValueSelector) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
convertUnsortedValuesToSorted(ColumnValueSelector) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
convertUnsortedValuesToSorted(ColumnValueSelector) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
copy() - Method in class org.apache.druid.jackson.DefaultObjectMapper
 
copy(DataSourceMetadataQuery) - Static method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
 
copy(ScanQuery) - Static method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
copy(SearchQuery) - Static method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
copy(SegmentMetadataQuery) - Static method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
copy(TimeBoundaryQuery) - Static method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
copy(TimeseriesQuery) - Static method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
copy() - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
copy() - Method in class org.apache.druid.query.groupby.ResultRow
Returns a copy of this row.
copy(TopNQuery) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
Deprecated.
copy(TopNQueryBuilder) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
Deprecated.
copyFrom(Histogram) - Method in class org.apache.druid.query.aggregation.Histogram
 
copyFrom(ReadableVectorMatch) - Method in class org.apache.druid.query.filter.vector.VectorMatch
Copies "other" into this object, and returns a reference to this object.
copyOf(ColumnCapabilities) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
copyTo(MemoryOpenHashTable, MemoryOpenHashTable.BucketCopyHandler) - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Copy this table into another one.
count - Variable in class org.apache.druid.query.aggregation.Histogram
 
COUNT_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
CountAggregator - Class in org.apache.druid.query.aggregation
 
CountAggregator() - Constructor for class org.apache.druid.query.aggregation.CountAggregator
 
CountAggregatorFactory - Class in org.apache.druid.query.aggregation
 
CountAggregatorFactory(String) - Constructor for class org.apache.druid.query.aggregation.CountAggregatorFactory
 
CountBufferAggregator - Class in org.apache.druid.query.aggregation
 
CountBufferAggregator() - Constructor for class org.apache.druid.query.aggregation.CountBufferAggregator
 
counter - Variable in class org.apache.druid.segment.IndexMerger.DictionaryMergeIterator
 
counts - Variable in class org.apache.druid.query.aggregation.HistogramVisual
 
CountVectorAggregator - Class in org.apache.druid.query.aggregation
 
CountVectorAggregator() - Constructor for class org.apache.druid.query.aggregation.CountVectorAggregator
 
CPUTimeMetricQueryRunner<T> - Class in org.apache.druid.query
 
create(QueryRunner<T>) - Method in class org.apache.druid.query.FluentQueryRunnerBuilder
 
create(int) - Static method in class org.apache.druid.query.groupby.ResultRow
Create a row of a certain size, initialized to all nulls.
create(DataSource, DataSource, String, String, JoinType, ExprMacroTable) - Static method in class org.apache.druid.query.JoinDataSource
Create a join dataSource from a string condition.
create(DataSource, DataSource, String, JoinConditionAnalysis, JoinType) - Static method in class org.apache.druid.query.JoinDataSource
Create a join dataSource from an existing JoinConditionAnalysis.
create(Lifecycle, DruidProcessingConfig) - Static method in class org.apache.druid.query.PrioritizedExecutorService
 
create(Granularity, boolean) - Static method in class org.apache.druid.query.ResultGranularTimestampComparator
 
create(String) - Static method in class org.apache.druid.query.TableDataSource
 
create(StorageAdapter, VectorCursor, Granularity, Interval) - Static method in class org.apache.druid.query.vector.VectorCursorGranularizer
 
create(ColumnarDoubles, ImmutableBitmap) - Static method in class org.apache.druid.segment.column.DoublesColumn
Factory method to create DoublesColumn.
create(ColumnarFloats, ImmutableBitmap) - Static method in class org.apache.druid.segment.column.FloatsColumn
Factory method to create FloatsColumn.
create(ColumnarLongs, ImmutableBitmap) - Static method in class org.apache.druid.segment.column.LongsColumn
Factory method to create LongsColumn.
create(String, SegmentWriteOutMedium, String, int, CompressionStrategy) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSerializer
 
create(Indexed<T>) - Static method in class org.apache.druid.segment.data.IndexedIterable
 
create(String, SegmentWriteOutMedium, String, int, CompressionStrategy) - Static method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSerializer
 
create(String, SegmentWriteOutMedium, String, CompressionStrategy) - Static method in class org.apache.druid.segment.DoubleColumnSerializer
 
create(String, SegmentWriteOutMedium, String, CompressionStrategy, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.DoubleColumnSerializerV2
 
create(String, SegmentWriteOutMedium, String, CompressionStrategy) - Static method in class org.apache.druid.segment.FloatColumnSerializer
 
create(String, SegmentWriteOutMedium, String, CompressionStrategy, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.FloatColumnSerializerV2
 
create(LookupExtractor, ColumnSelectorFactory, JoinConditionAnalysis, boolean) - Static method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
 
create(String, SegmentWriteOutMedium, String, CompressionStrategy, CompressionFactory.LongEncodingStrategy) - Static method in class org.apache.druid.segment.LongColumnSerializer
 
create(String, SegmentWriteOutMedium, String, CompressionStrategy, CompressionFactory.LongEncodingStrategy, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.LongColumnSerializerV2
 
create(RowAdapter<RowType>, Supplier<RowType>, RowSignature, boolean) - Static method in class org.apache.druid.segment.RowBasedColumnSelectorFactory
Create an instance based on any object, along with a RowAdapter for that object.
create(SegmentWriteOutMedium, String, ObjectStrategy) - Static method in class org.apache.druid.segment.serde.ComplexColumnSerializer
 
create(SegmentWriteOutMedium, String, ObjectStrategy) - Static method in class org.apache.druid.segment.serde.LargeColumnSupportedComplexColumnSerializer
 
create(VectorOffset, VectorColumnSelectorFactory, Filter) - Static method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
create(VectorSizeInspector) - Static method in class org.apache.druid.segment.vector.NilVectorSelector
 
create(List<VirtualColumn>) - Static method in class org.apache.druid.segment.VirtualColumns
 
createBySegmentAccumulatorPair() - Static method in class org.apache.druid.query.groupby.GroupByQueryHelper
 
createClauses(List<PreJoinableClause>, JoinableFactory) - Static method in class org.apache.druid.segment.join.filter.JoinableClauses
Builds a list of JoinableClause corresponding to a list of PreJoinableClause.
createColumnSelectorPlus(ColumnSelectorStrategyFactory<Strategy>, DimensionSpec, ColumnSelectorFactory) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
Convenience function equivalent to calling DimensionHandlerUtils.createColumnSelectorPluses(ColumnSelectorStrategyFactory, List, ColumnSelectorFactory) with a singleton list of dimensionSpecs and then retrieving the only element in the returned array.
createColumnSelectorPluses(ColumnSelectorStrategyFactory<Strategy>, List<DimensionSpec>, ColumnSelectorFactory) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
Creates an array of ColumnSelectorPlus objects, selectors that handle type-specific operations within query processing engines, using a strategy factory provided by the query engine.
createDefault(Filter, BitmapIndexSelector) - Static method in class org.apache.druid.query.filter.FilterTuning
 
createDefault() - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
Creates a ColumnCapabilitiesImpl where all ColumnCapabilities.Capable that default to unknown instead are coerced to true or false
createDeserializer(String) - Static method in class org.apache.druid.segment.serde.ComplexColumnPartSerde
 
createDeserializer(BitmapSerdeFactory, ByteOrder) - Static method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
 
createDeserializer(ByteOrder) - Static method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde
 
createDeserializer(ByteOrder, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2
 
createDeserializer(ByteOrder) - Static method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde
 
createDeserializer(ByteOrder, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2
 
createEmpty() - Static method in class org.apache.druid.query.context.ConcurrentResponseContext
 
createEmpty() - Static method in class org.apache.druid.query.context.DefaultResponseContext
 
createEmpty() - Static method in class org.apache.druid.query.context.ResponseContext
Create an empty DefaultResponseContext instance
createFile() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage
Create a new temporary file.
createGrouperAccumulatorPair(GroupByQuery, GroupByQuery, GroupByQueryConfig, Supplier<ByteBuffer>, LimitedTemporaryStorage, ObjectMapper, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper
Create a single-threaded grouper and accumulator.
createGrouperAccumulatorPair(GroupByQuery, GroupByQuery, GroupByQueryConfig, Supplier<ByteBuffer>, ReferenceCountingResourceHolder<ByteBuffer>, int, LimitedTemporaryStorage, ObjectMapper, ListeningExecutorService, int, boolean, long, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper
Create a Grouper that groups according to the dimensions and aggregators in "query", along with an Accumulator that accepts ResultRows and forwards them to the grouper.
createIndexAccumulatorPair(GroupByQuery, GroupByQuery, GroupByQueryConfig, NonBlockingPool<ByteBuffer>) - Static method in class org.apache.druid.query.groupby.GroupByQueryHelper
 
createLegacyFactory() - Static method in class org.apache.druid.segment.data.BitmapSerde
 
createMergeFn(Query<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
createMergeFn(Query<ResultRow>) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
See QueryToolChest.createMergeFn(Query) for details, allows GroupByQueryQueryToolChest to delegate implementation to the strategy
createMergeFn(Query<ResultRow>) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
createMergeFn(Query<SegmentAnalysis>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
createMergeFn(Query<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
Creates a merge function that is used to merge intermediate aggregates from historicals in broker.
createMergeFn(Query<Result<SearchResultValue>>) - Method in class org.apache.druid.query.search.SearchQueryQueryToolChest
 
createMergeFn(Query<Result<TimeBoundaryResultValue>>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
createMergeFn(Query<Result<TimeseriesResultValue>>) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
createMergeFn(Query<Result<TopNResultValue>>) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
createNoPushdownFilterAnalysis(Filter) - Static method in class org.apache.druid.segment.join.filter.JoinFilterAnalysis
Utility method for generating an analysis that represents: "Filter cannot be pushed down"
createResultComparator(Query<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
createResultComparator(Query<ResultRow>) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
See QueryToolChest.createResultComparator(Query), allows GroupByQueryQueryToolChest to delegate implementation to the strategy
createResultComparator(Query<ResultRow>) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
createResultComparator(Query<SegmentAnalysis>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
createResultComparator(Query<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
Creates an ordering comparator that is used to order results.
createResultComparator(Query<Result<SearchResultValue>>) - Method in class org.apache.druid.query.search.SearchQueryQueryToolChest
 
createResultComparator(Query<Result<TimeBoundaryResultValue>>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
createResultComparator(Query<Result<TimeseriesResultValue>>) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
createResultComparator(Query<Result<TopNResultValue>>) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
createResultRowBasedColumnSelectorFactory(GroupByQuery, Supplier<ResultRow>) - Static method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper
Creates a ColumnSelectorFactory that can read rows which originate as results of the provided "query".
createRowIngestionMeters() - Method in interface org.apache.druid.segment.incremental.RowIngestionMetersFactory
 
createRunner(Segment) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQueryRunnerFactory
 
createRunner(Segment) - Method in class org.apache.druid.query.groupby.GroupByQueryRunnerFactory
 
createRunner(Segment) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryRunnerFactory
 
createRunner(Segment) - Method in interface org.apache.druid.query.QueryRunnerFactory
Given a specific segment, this method will create a QueryRunner.
createRunner(Segment) - Method in class org.apache.druid.query.scan.ScanQueryRunnerFactory
 
createRunner(Segment) - Method in class org.apache.druid.query.search.SearchQueryRunnerFactory
 
createRunner(Segment) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryRunnerFactory
 
createRunner(Segment) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryRunnerFactory
 
createRunner(Segment) - Method in class org.apache.druid.query.topn.TopNQueryRunnerFactory
 
createSegmentMapFn(List<PreJoinableClause>, JoinableFactory, AtomicLong, Query<?>) - Static method in class org.apache.druid.segment.join.Joinables
Creates a Function that maps base segments to HashJoinSegment if needed (i.e.
createSimpleArrayColumnCapabilities(ValueType) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
createSimpleNumericColumnCapabilities(ValueType) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
Create a no frills, simple column with ValueType set and everything else false
createWithColumnSize(SegmentWriteOutMedium, String, ObjectStrategy, int) - Static method in class org.apache.druid.segment.serde.LargeColumnSupportedComplexColumnSerializer
 
CTX_GRAND_TOTAL - Static variable in class org.apache.druid.query.timeseries.TimeseriesQuery
 
CTX_KEY_APPLY_LIMIT_PUSH_DOWN - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
 
CTX_KEY_APPLY_LIMIT_PUSH_DOWN_TO_SEGMENT - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
 
CTX_KEY_ARRAY_RESULT_ROWS - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
 
CTX_KEY_EXECUTING_NESTED_QUERY - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
 
CTX_KEY_FORCE_LIMIT_PUSH_DOWN - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
 
CTX_KEY_FORCE_PUSH_DOWN_NESTED_QUERY - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
 
CTX_KEY_FUDGE_TIMESTAMP - Static variable in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
CTX_KEY_MAX_ROWS_QUEUED_FOR_ORDERING - Static variable in class org.apache.druid.query.scan.ScanQueryConfig
 
CTX_KEY_MAX_SEGMENT_PARTITIONS_FOR_ORDERING - Static variable in class org.apache.druid.query.scan.ScanQueryConfig
 
CTX_KEY_OUTERMOST - Static variable in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
CTX_KEY_OUTERMOST - Static variable in class org.apache.druid.query.scan.ScanQuery
This context flag corresponds to whether the query is running on the "outermost" process (i.e.
CTX_KEY_SORT_BY_DIMS_FIRST - Static variable in class org.apache.druid.query.groupby.GroupByQuery
 
CTX_KEY_SORT_RESULTS - Static variable in class org.apache.druid.query.groupby.GroupByQueryHelper
 
CTX_KEY_STRATEGY - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
 
CTX_KEY_STRATEGY - Static variable in class org.apache.druid.query.search.SearchQueryConfig
 
CTX_TIMESTAMP_RESULT_FIELD - Static variable in class org.apache.druid.query.timeseries.TimeseriesQuery
 
cumulativeProbability(int) - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
CURRENT_VERSION_ID - Static variable in class org.apache.druid.segment.IndexIO
 
currentRow() - Method in class org.apache.druid.segment.RowWalker
 
cursor(Cursor) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
cursor(Cursor) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
This method is called exactly once with each cursor, processed for the query.
Cursor - Interface in org.apache.druid.segment
Cursor is an interface for iteration over a range of data points, used during query execution.
CursorBasedExecutor(SearchQuery, Segment, Filter, Interval, List<DimensionSpec>) - Constructor for class org.apache.druid.query.search.CursorOnlyStrategy.CursorBasedExecutor
 
CursorFactory - Interface in org.apache.druid.segment
Interface extended by StorageAdapter, which gives them the power to create cursors.
CursorOnlyStrategy - Class in org.apache.druid.query.search
 
CursorOnlyStrategy.CursorBasedExecutor - Class in org.apache.druid.query.search
 

D

DATA_SKETCHES_SKETCH_ESTIMATE - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
DATA_SKETCHES_SKETCH_SET - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
DataGenerator - Class in org.apache.druid.segment.generator
 
DataGenerator(List<GeneratorColumnSchema>, long, long, int, Double) - Constructor for class org.apache.druid.segment.generator.DataGenerator
 
DataGenerator(List<GeneratorColumnSchema>, long, Interval, int) - Constructor for class org.apache.druid.segment.generator.DataGenerator
 
DataSource - Interface in org.apache.druid.query
Represents a source...
dataSource(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
DATASOURCE - Static variable in class org.apache.druid.query.DruidMetrics
 
dataSource(String) - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
 
dataSource(DataSource) - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
 
dataSource(String) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
dataSource(DataSource) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
dataSource(String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
dataSource(DataSource) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
dataSource(String) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
dataSource(DataSource) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
dataSource(String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
dataSource(DataSource) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
dataSource(String) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
dataSource(DataSource) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
dataSource(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.getDataSource() of the given query as dimension.
dataSource(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
dataSource(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
dataSource(DataSource) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
DATASOURCE_METADATA - Static variable in interface org.apache.druid.query.Query
 
DataSourceAnalysis - Class in org.apache.druid.query.planning
Analysis of a datasource for purposes of deciding how to execute a particular query.
DataSourceMetadataQuery - Class in org.apache.druid.query.datasourcemetadata
 
DataSourceMetadataQuery(DataSource, QuerySegmentSpec, Map<String, Object>) - Constructor for class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
DataSourceMetadataQueryBuilder() - Constructor for class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
 
DataSourceMetadataQueryRunnerFactory - Class in org.apache.druid.query.datasourcemetadata
 
DataSourceMetadataQueryRunnerFactory(DataSourceQueryQueryToolChest, QueryWatcher) - Constructor for class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQueryRunnerFactory
 
DataSourceMetadataResultValue - Class in org.apache.druid.query.datasourcemetadata
 
DataSourceMetadataResultValue(DateTime) - Constructor for class org.apache.druid.query.datasourcemetadata.DataSourceMetadataResultValue
 
DataSourceQueryQueryToolChest - Class in org.apache.druid.query.datasourcemetadata
 
DataSourceQueryQueryToolChest(GenericQueryMetricsFactory) - Constructor for class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
 
debugToString() - Method in interface org.apache.druid.segment.data.IndexedInts
 
decode(String) - Static method in class org.apache.druid.segment.incremental.SpatialDimensionRowTransformer
Decodes encodedCoordinate.
decomposeConjunction(Filter, List<Filter>) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
Decomposes a predicate into a list of expressions that are AND'ed together.
decompress(ByteBuffer, int, ByteBuffer) - Method in interface org.apache.druid.segment.data.CompressionStrategy.Decompressor
Implementations of this method are expected to call out.flip() after writing to the output buffer
decompress(ByteBuffer, int, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.LZ4Decompressor
 
decompress(ByteBuffer, int, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.LZFDecompressor
 
decompress(ByteBuffer, int, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.UncompressedDecompressor
 
DecompressingByteBufferObjectStrategy - Class in org.apache.druid.segment.data
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
decorate(Map<String, AggregatorFactory>) - Method in interface org.apache.druid.query.aggregation.PostAggregator
Allows returning an enriched post aggregator, built from contextual information available from the given map of AggregatorFactory keyed by their names.
decorate(DimensionSelector) - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
decorate(SingleValueDimensionVectorSelector) - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
decorate(MultiValueDimensionVectorSelector) - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
decorate(DimensionSelector) - Method in interface org.apache.druid.query.dimension.DimensionSpec
 
decorate(SingleValueDimensionVectorSelector) - Method in interface org.apache.druid.query.dimension.DimensionSpec
 
decorate(MultiValueDimensionVectorSelector) - Method in interface org.apache.druid.query.dimension.DimensionSpec
 
decorate(DimensionSelector) - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
decorate(DimensionSelector) - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
decorate(DimensionSelector) - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
decorate(DimensionSelector) - Method in class org.apache.druid.query.dimension.PrefixFilteredDimensionSpec
 
decorate(DimensionSelector) - Method in class org.apache.druid.query.dimension.RegexFilteredDimensionSpec
 
decorate(InputRowParser<T>) - Method in class org.apache.druid.segment.transform.TransformSpec
 
decorate(InputSourceReader) - Method in class org.apache.druid.segment.transform.TransformSpec
 
decorateObjectMapper(ObjectMapper, GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
decorateObjectMapper(ObjectMapper, QueryType) - Method in class org.apache.druid.query.QueryToolChest
Perform any per-query decoration of an ObjectMapper that enables it to read and write objects of the query's ResultType.
decoratePostAggregators(List<PostAggregator>, Map<String, AggregatorFactory>) - Static method in class org.apache.druid.query.Queries
 
decrement() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
Decrement the reference count by one.
decrementOnceCloseable() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
Returns a Closeable which action is to call ReferenceCountingCloseableObject.decrement() only once.
DEFAULT_BY_SEGMENT - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
DEFAULT_COMPRESS_RUN_ON_SERIALIZATION - Static variable in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
 
DEFAULT_COMPRESSION_STRATEGY - Static variable in enum org.apache.druid.segment.data.CompressionStrategy
 
DEFAULT_DIMENSION_COMPRESSION - Static variable in class org.apache.druid.segment.IndexSpec
 
DEFAULT_DIMENSION_ORDER - Static variable in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
DEFAULT_ENABLE_JOIN_FILTER_PUSH_DOWN - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_ENABLE_JOIN_FILTER_REWRITE - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_ENABLE_JOIN_FILTER_REWRITE_MAX_SIZE - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_ENABLE_JOIN_FILTER_REWRITE_VALUE_COLUMN_FILTERS - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_ENABLE_PARALLEL_MERGE - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_LONG_ENCODING - Static variable in class org.apache.druid.segment.IndexSpec
 
DEFAULT_LONG_ENCODING_STRATEGY - Static variable in class org.apache.druid.segment.data.CompressionFactory
 
DEFAULT_MAX_STRING_SIZE - Static variable in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
DEFAULT_MERGE_POOL_AWAIT_SHUTDOWN_MILLIS - Static variable in class org.apache.druid.query.DruidProcessingConfig
 
DEFAULT_METRIC_COMPRESSION - Static variable in class org.apache.druid.segment.IndexSpec
 
DEFAULT_NUM_MERGE_BUFFERS - Static variable in class org.apache.druid.query.DruidProcessingConfig
 
DEFAULT_ORDERING - Static variable in class org.apache.druid.query.search.SearchSortSpec
 
DEFAULT_POPULATE_CACHE - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_POPULATE_RESULTLEVEL_CACHE - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_PRIORITY - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_PROCESSING_BUFFER_SIZE_BYTES - Static variable in class org.apache.druid.query.DruidProcessingConfig
 
DEFAULT_SECONDARY_PARTITION_PRUNING - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_STRING_CAPABILITIES - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
 
DEFAULT_TIMEOUT_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_TIMEOUT_MILLIS - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_UNCOVERED_INTERVALS_LIMIT - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_USE_CACHE - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_USE_FILTER_CNF - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_USE_RESULTLEVEL_CACHE - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_VECTOR_SIZE - Static variable in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
DEFAULT_VECTORIZE - Static variable in class org.apache.druid.query.QueryContexts
 
DEFAULT_VECTORIZE_VIRTUAL_COLUMN - Static variable in class org.apache.druid.query.QueryContexts
 
DefaultBitmapResultFactory - Class in org.apache.druid.query
 
DefaultBitmapResultFactory(BitmapFactory) - Constructor for class org.apache.druid.query.DefaultBitmapResultFactory
 
DefaultBitmapSerdeFactory() - Constructor for class org.apache.druid.segment.data.BitmapSerde.DefaultBitmapSerdeFactory
 
DefaultDimensionSpec - Class in org.apache.druid.query.dimension
 
DefaultDimensionSpec(String, String, ValueType) - Constructor for class org.apache.druid.query.dimension.DefaultDimensionSpec
 
DefaultDimensionSpec(String, String) - Constructor for class org.apache.druid.query.dimension.DefaultDimensionSpec
 
DefaultGenericQueryMetricsFactory - Class in org.apache.druid.query
 
DefaultGenericQueryMetricsFactory() - Constructor for class org.apache.druid.query.DefaultGenericQueryMetricsFactory
 
defaultGetObject() - Method in interface org.apache.druid.segment.DimensionSelector
Converts the current result of DimensionSelector.getRow() into null, if the row is empty, a String, if the row has size 1, or a String[] array, if the row has size > 1, using DimensionDictionarySelector.lookupName(int).
DefaultGroupByQueryMetrics - Class in org.apache.druid.query.groupby
 
DefaultGroupByQueryMetrics() - Constructor for class org.apache.druid.query.groupby.DefaultGroupByQueryMetrics
 
DefaultGroupByQueryMetricsFactory - Class in org.apache.druid.query.groupby
 
DefaultGroupByQueryMetricsFactory() - Constructor for class org.apache.druid.query.groupby.DefaultGroupByQueryMetricsFactory
 
DefaultIndexIOHandler() - Constructor for class org.apache.druid.segment.IndexIO.DefaultIndexIOHandler
 
DefaultLimitSpec - Class in org.apache.druid.query.groupby.orderby
 
DefaultLimitSpec(List<OrderByColumnSpec>, Integer, Integer) - Constructor for class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
DefaultLimitSpec(List<OrderByColumnSpec>, Integer) - Constructor for class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
Constructor that does not accept "offset".
DefaultLimitSpec.Builder - Class in org.apache.druid.query.groupby.orderby
 
DefaultObjectMapper - Class in org.apache.druid.jackson
 
DefaultObjectMapper() - Constructor for class org.apache.druid.jackson.DefaultObjectMapper
 
DefaultObjectMapper(DefaultObjectMapper) - Constructor for class org.apache.druid.jackson.DefaultObjectMapper
 
DefaultObjectMapper(JsonFactory) - Constructor for class org.apache.druid.jackson.DefaultObjectMapper
 
DefaultQueryConfig - Class in org.apache.druid.query
A user configuration holder for all query types.
DefaultQueryConfig(Map<String, Object>) - Constructor for class org.apache.druid.query.DefaultQueryConfig
 
DefaultQueryMetrics<QueryType extends Query<?>> - Class in org.apache.druid.query
DefaultQueryMetrics is unsafe for use from multiple threads.
DefaultQueryMetrics() - Constructor for class org.apache.druid.query.DefaultQueryMetrics
 
DefaultQueryRunnerFactoryConglomerate - Class in org.apache.druid.query
 
DefaultQueryRunnerFactoryConglomerate(Map<Class<? extends Query>, QueryRunnerFactory>) - Constructor for class org.apache.druid.query.DefaultQueryRunnerFactoryConglomerate
 
DefaultResponseContext - Class in org.apache.druid.query.context
The implementation of ResponseContext with a HashMap as a delegate
DefaultResponseContext() - Constructor for class org.apache.druid.query.context.DefaultResponseContext
 
DefaultSearchQueryMetrics - Class in org.apache.druid.query.search
This class is implemented with delegation to another QueryMetrics for compatibility, see "Making subinterfaces of QueryMetrics for emitting custom dimensions and/or metrics for specific query types" section in QueryMetrics javadoc.
DefaultSearchQueryMetrics(QueryMetrics<Query<?>>) - Constructor for class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
DefaultSearchQueryMetricsFactory - Class in org.apache.druid.query.search
 
DefaultSearchQueryMetricsFactory(GenericQueryMetricsFactory) - Constructor for class org.apache.druid.query.search.DefaultSearchQueryMetricsFactory
 
DefaultTimeseriesQueryMetrics - Class in org.apache.druid.query.timeseries
 
DefaultTimeseriesQueryMetrics() - Constructor for class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetrics
 
DefaultTimeseriesQueryMetricsFactory - Class in org.apache.druid.query.timeseries
 
DefaultTimeseriesQueryMetricsFactory() - Constructor for class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetricsFactory
 
DefaultTopNQueryMetrics - Class in org.apache.druid.query.topn
 
DefaultTopNQueryMetrics() - Constructor for class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
DefaultTopNQueryMetricsFactory - Class in org.apache.druid.query.topn
 
DefaultTopNQueryMetricsFactory() - Constructor for class org.apache.druid.query.topn.DefaultTopNQueryMetricsFactory
 
defaultType() - Method in interface org.apache.druid.segment.ColumnProcessorFactory
This default type will be used when the underlying column has an unknown type.
defaultType() - Method in class org.apache.druid.segment.filter.ConstantValueMatcherFactory
 
defaultType() - Method in class org.apache.druid.segment.filter.PredicateValueMatcherFactory
 
delegate - Variable in class org.apache.druid.query.aggregation.DelegatingAggregator
 
delegate - Variable in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
delegate - Variable in class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
delegate() - Method in class org.apache.druid.query.MetricsEmittingExecutorService
 
DelegatingAggregator - Class in org.apache.druid.query.aggregation
An Aggregator that delegates everything.
DelegatingAggregator() - Constructor for class org.apache.druid.query.aggregation.DelegatingAggregator
 
DelegatingBufferAggregator - Class in org.apache.druid.query.aggregation
A BufferAggregator that delegates everything.
DelegatingBufferAggregator() - Constructor for class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
delete(File) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage
 
DELTA_ENCODING_VERSION - Static variable in class org.apache.druid.segment.data.CompressionFactory
Delta Encoding Header v1: Byte 1 : version Byte 2 - 9 : base value Byte 10 - 13 : number of bits per value
DeltaLongEncodingReader - Class in org.apache.druid.segment.data
 
DeltaLongEncodingReader(ByteBuffer) - Constructor for class org.apache.druid.segment.data.DeltaLongEncodingReader
 
DeltaLongEncodingWriter - Class in org.apache.druid.segment.data
 
DeltaLongEncodingWriter(long, long) - Constructor for class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
depthFirstSearch(ImmutableNode, Bound) - Method in class org.apache.druid.collections.spatial.search.GutmanSearchStrategy
 
desc(String) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
descending(boolean) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
descending(String...) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
A method that knows how to "deserialize" the object from whatever form it might have been put into in order to transfer via JSON.
deserialize(Object) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
deserialize(Object) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
deserialize(String, ObjectMapper) - Static method in class org.apache.druid.query.context.ResponseContext
Deserializes a string into ResponseContext using given ObjectMapper.
deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
 
deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringSerde
 
deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
Deserializes a ByteBuffer and adds it to the ColumnBuilder.
deserializing() - Static method in class org.apache.druid.query.aggregation.MetricManipulatorFns
 
destroy() - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
This method will be called to drop the LookupExtractor upon explicit user request to coordinator to drop this lookup.
DETERMINE_PARTITIONS - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
determineBaseColumnsWithPreAndPostJoinVirtualColumns(VirtualColumns, List<VirtualColumn>, List<VirtualColumn>) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
Return a String set containing the name of columns that belong to the base table (including any pre-join virtual columns as well).
DictionaryBuildingStringGroupByColumnSelectorStrategy - Class in org.apache.druid.query.groupby.epinephelinae.column
A String strategy that builds an internal String<->Integer dictionary for DimensionSelectors that return false for nameLookupPossibleInAdvance()
DictionaryBuildingStringGroupByColumnSelectorStrategy() - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.DictionaryBuildingStringGroupByColumnSelectorStrategy
 
dictionaryEncoded() - Method in interface org.apache.druid.segment.column.ColumnCapabilities.CoercionLogic
If ColumnCapabilities.isDictionaryEncoded() is ColumnCapabilities.Capable.UNKNOWN, define if it should be treated as true or false.
DictionaryEncodedColumn<ActualType extends Comparable<? super ActualType>> - Interface in org.apache.druid.segment.column
 
DictionaryEncodedColumnPartSerde - Class in org.apache.druid.segment.serde
 
DictionaryEncodedColumnPartSerde.SerializerBuilder - Class in org.apache.druid.segment.serde
 
DictionaryEncodedColumnSupplier - Class in org.apache.druid.segment.serde
 
DictionaryEncodedColumnSupplier(GenericIndexed<String>, Supplier<ColumnarInts>, Supplier<ColumnarMultiInts>, int) - Constructor for class org.apache.druid.segment.serde.DictionaryEncodedColumnSupplier
 
dictionaryFull(int) - Static method in class org.apache.druid.query.groupby.epinephelinae.Groupers
 
dictionaryValuesSorted() - Method in interface org.apache.druid.segment.column.ColumnCapabilities.CoercionLogic
If ColumnCapabilities.areDictionaryValuesSorted() ()} is ColumnCapabilities.Capable.UNKNOWN, define if it should be treated as true or false.
dictionaryValuesUnique() - Method in interface org.apache.druid.segment.column.ColumnCapabilities.CoercionLogic
If ColumnCapabilities.areDictionaryValuesUnique() ()} is ColumnCapabilities.Capable.UNKNOWN, define if it should be treated as true or false.
dimension(TopNQuery) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
dimension(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
dimension(String, String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
dimension(DimensionSpec) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
dimension(TopNQuery) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
Sets TopNQuery.getDimensionSpec().getDimension() of the given query as dimension.
dimension - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
DIMENSION_CAPABILITY_MERGE_LOGIC - Static variable in class org.apache.druid.segment.IndexMergerV9
 
DIMENSION_IDENTITY - Static variable in class org.apache.druid.query.Druids
 
DimensionAndMetricValueExtractor - Class in org.apache.druid.query.topn
 
DimensionAndMetricValueExtractor(Map<String, Object>) - Constructor for class org.apache.druid.query.topn.DimensionAndMetricValueExtractor
 
dimensionCardinality(int) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
dimensionCardinality(int) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
 
DimensionDesc(int, String, DimensionHandler) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
 
DimensionDictionarySelector - Interface in org.apache.druid.segment
Interface containing dictionary-related methods common to DimensionSelector, SingleValueDimensionVectorSelector, and MultiValueDimensionVectorSelector.
DimensionHandler<EncodedType extends Comparable<EncodedType>,EncodedKeyComponentType,ActualType extends Comparable<ActualType>> - Interface in org.apache.druid.segment
Processing related interface A DimensionHandler is an object that encapsulates indexing, column merging/building, and querying operations for a given dimension type (e.g., dict-encoded String, Long).
DimensionHandlerUtils - Class in org.apache.druid.segment
 
DimensionIndexer<EncodedType extends Comparable<EncodedType>,EncodedKeyComponentType,ActualType extends Comparable<ActualType>> - Interface in org.apache.druid.segment
Processing related interface A DimensionIndexer is a per-dimension stateful object that encapsulates type-specific operations and data structures used during the in-memory ingestion process (i.e., work done by IncrementalIndex).
DimensionMerger - Interface in org.apache.druid.segment
Processing related interface A DimensionMerger is a per-dimension stateful object that encapsulates type-specific operations and data structures used during the segment merging process (i.e., work done by IndexMerger).
DimensionMergerV9 - Interface in org.apache.druid.segment
Processing related interface DimensionMerger subclass to be used with IndexMergerV9.
dimensionName - Variable in class org.apache.druid.segment.NumericDimensionMergerV9
 
DimensionPredicateFilter - Class in org.apache.druid.segment.filter
 
DimensionPredicateFilter(String, DruidPredicateFactory, ExtractionFn) - Constructor for class org.apache.druid.segment.filter.DimensionPredicateFilter
 
DimensionPredicateFilter(String, DruidPredicateFactory, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.segment.filter.DimensionPredicateFilter
 
dimensions(String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
dimensions(Iterable<String>) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
dimensions(DimensionSpec) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
dimensions(List<DimensionSpec>) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
DimensionSelector - Interface in org.apache.druid.segment
Selector for a string-typed column, either single- or multi-valued.
DimensionSelector.NullDimensionSelectorHolder - Class in org.apache.druid.segment
This class not a public API.
DimensionSelectorHavingSpec - Class in org.apache.druid.query.groupby.having
 
DimensionSelectorHavingSpec(String, String, ExtractionFn) - Constructor for class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
DimensionSelectorUtils - Class in org.apache.druid.segment
 
DimensionSpec - Interface in org.apache.druid.query.dimension
Provides information about a dimension for a grouping query, like topN or groupBy.
DimensionTopNMetricSpec - Class in org.apache.druid.query.topn
 
DimensionTopNMetricSpec(String, StringComparator) - Constructor for class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
dimEquals(String, String) - Static method in class org.apache.druid.query.filter.DimFilters
 
DimExtractionFn - Class in org.apache.druid.query.extraction
 
DimExtractionFn() - Constructor for class org.apache.druid.query.extraction.DimExtractionFn
 
DimFilter - Interface in org.apache.druid.query.filter
 
DimFilter.DimFilterToStringBuilder - Class in org.apache.druid.query.filter
Wrapper for StringBuilder to re-use common patterns in custom DimFilter#toString() implementations
DimFilterHavingSpec - Class in org.apache.druid.query.groupby.having
 
DimFilterHavingSpec(DimFilter, Boolean) - Constructor for class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
DimFilters - Class in org.apache.druid.query.filter
 
DimFilters() - Constructor for class org.apache.druid.query.filter.DimFilters
 
DimFilterToStringBuilder() - Constructor for class org.apache.druid.query.filter.DimFilter.DimFilterToStringBuilder
 
DimFilterUtils - Class in org.apache.druid.query.filter
 
DimFilterUtils() - Constructor for class org.apache.druid.query.filter.DimFilterUtils
 
dimsComparator() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
dimsToSearch - Variable in class org.apache.druid.query.search.SearchQueryExecutor
 
DimValHolder - Class in org.apache.druid.query.topn
 
DimValHolder(Object, Comparable, Object, Map<String, Object>) - Constructor for class org.apache.druid.query.topn.DimValHolder
 
DimValHolder.Builder - Class in org.apache.druid.query.topn
 
directBufferAllocations - Variable in class org.apache.druid.segment.IndexMerger.DictionaryMergeIterator
 
DISTINCT_COUNT_CACHE_KEY - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
doesFilterSupportDirectJoinFilterRewrite(Filter) - Method in class org.apache.druid.segment.join.filter.Equiconditions
 
doGet(ByteBuffer, int) - Static method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
doInit(ByteBuffer, int) - Static method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
doMergeResults(GroupByQuery) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Indicates if this query should undergo "mergeResults" or not.
doMergeResults(GroupByQuery) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
doMergeResults(GroupByQuery) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
doMonitor(ServiceEmitter) - Method in class org.apache.druid.query.ExecutorServiceMonitor
 
doRun(QueryRunner<T>, QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.BySegmentSkippingQueryRunner
 
doRun(QueryRunner<T>, QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.ResultMergeQueryRunner
 
DOUBLE_ANY_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
DOUBLE_COMPARATOR - Static variable in class org.apache.druid.segment.DoubleDimensionIndexer
 
DOUBLE_FIRST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
DOUBLE_GREATEST - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
DOUBLE_LAST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
DOUBLE_LEAST - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
DOUBLE_MAX_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
DOUBLE_MIN_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
DOUBLE_STORAGE_TYPE_PROPERTY - Static variable in interface org.apache.druid.segment.column.ColumnHolder
 
DOUBLE_SUM_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
DoubleAggregateCombiner - Class in org.apache.druid.query.aggregation
Specialization of AggregateCombiner for primitive double aggregations.
DoubleAggregateCombiner() - Constructor for class org.apache.druid.query.aggregation.DoubleAggregateCombiner
 
DoubleAnyAggregator - Class in org.apache.druid.query.aggregation.any
 
DoubleAnyAggregator(BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.DoubleAnyAggregator
 
DoubleAnyAggregatorFactory - Class in org.apache.druid.query.aggregation.any
 
DoubleAnyAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
DoubleAnyBufferAggregator - Class in org.apache.druid.query.aggregation.any
 
DoubleAnyBufferAggregator(BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
 
DoubleAnyVectorAggregator - Class in org.apache.druid.query.aggregation.any
Vectorized implementation of the DoubleAnyBufferAggregator
DoubleAnyVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.DoubleAnyVectorAggregator
 
DoubleCardinalityAggregatorColumnSelectorStrategy - Class in org.apache.druid.query.aggregation.cardinality.types
If performance of this class appears to be a bottleneck for somebody, one simple way to improve it is to split it into two different classes, one that is used when NullHandling.replaceWithDefault() is false, and one - when it's true, moving this computation out of the tight loop
DoubleCardinalityAggregatorColumnSelectorStrategy() - Constructor for class org.apache.druid.query.aggregation.cardinality.types.DoubleCardinalityAggregatorColumnSelectorStrategy
 
DoubleColumnSelector - Interface in org.apache.druid.segment
This interface is convenient for implementation of "double-sourcing" ColumnValueSelectors, it provides default implementations for all ColumnValueSelector's methods except BaseDoubleColumnValueSelector.getDouble().
DoubleColumnSerializer - Class in org.apache.druid.segment
 
DoubleColumnSerializerV2 - Class in org.apache.druid.segment
Column Serializer for double column.
DoubleDimensionHandler - Class in org.apache.druid.segment
 
DoubleDimensionHandler(String) - Constructor for class org.apache.druid.segment.DoubleDimensionHandler
 
DoubleDimensionIndexer - Class in org.apache.druid.segment
 
DoubleDimensionIndexer() - Constructor for class org.apache.druid.segment.DoubleDimensionIndexer
 
DoubleDimensionMergerV9 - Class in org.apache.druid.segment
 
DoubleFirstAggregator - Class in org.apache.druid.query.aggregation.first
 
DoubleFirstAggregator(BaseLongColumnValueSelector, BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.first.DoubleFirstAggregator
 
DoubleFirstAggregatorFactory - Class in org.apache.druid.query.aggregation.first
 
DoubleFirstAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
DoubleFirstBufferAggregator - Class in org.apache.druid.query.aggregation.first
 
DoubleFirstBufferAggregator(BaseLongColumnValueSelector, BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.first.DoubleFirstBufferAggregator
 
DoubleGreatestPostAggregator - Class in org.apache.druid.query.aggregation.post
 
DoubleGreatestPostAggregator(String, List<PostAggregator>) - Constructor for class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
DoubleGroupByColumnSelectorStrategy - Class in org.apache.druid.query.groupby.epinephelinae.column
 
DoubleGroupByColumnSelectorStrategy() - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
DoubleGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
DoubleLastAggregator - Class in org.apache.druid.query.aggregation.last
 
DoubleLastAggregator(BaseLongColumnValueSelector, BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.last.DoubleLastAggregator
 
DoubleLastAggregatorFactory - Class in org.apache.druid.query.aggregation.last
 
DoubleLastAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
DoubleLastBufferAggregator - Class in org.apache.druid.query.aggregation.last
 
DoubleLastBufferAggregator(BaseLongColumnValueSelector, BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.last.DoubleLastBufferAggregator
 
DoubleLeastPostAggregator - Class in org.apache.druid.query.aggregation.post
 
DoubleLeastPostAggregator(String, List<PostAggregator>) - Constructor for class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
DoubleMaxAggregator - Class in org.apache.druid.query.aggregation
 
DoubleMaxAggregator(BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.DoubleMaxAggregator
 
DoubleMaxAggregatorFactory - Class in org.apache.druid.query.aggregation
 
DoubleMaxAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
DoubleMaxAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
DoubleMaxBufferAggregator - Class in org.apache.druid.query.aggregation
 
DoubleMaxVectorAggregator - Class in org.apache.druid.query.aggregation
 
DoubleMaxVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.DoubleMaxVectorAggregator
 
DoubleMeanAggregator - Class in org.apache.druid.query.aggregation.mean
 
DoubleMeanAggregator(ColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
 
DoubleMeanAggregatorFactory - Class in org.apache.druid.query.aggregation.mean
 
DoubleMeanAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
DoubleMeanBufferAggregator - Class in org.apache.druid.query.aggregation.mean
 
DoubleMeanBufferAggregator(ColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
DoubleMeanHolder - Class in org.apache.druid.query.aggregation.mean
 
DoubleMeanHolder(double, long) - Constructor for class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
DoubleMeanHolder.Serializer - Class in org.apache.druid.query.aggregation.mean
 
DoubleMeanVectorAggregator - Class in org.apache.druid.query.aggregation.mean
 
DoubleMeanVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.mean.DoubleMeanVectorAggregator
 
DoubleMinAggregator - Class in org.apache.druid.query.aggregation
 
DoubleMinAggregator(BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.DoubleMinAggregator
 
DoubleMinAggregatorFactory - Class in org.apache.druid.query.aggregation
 
DoubleMinAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
DoubleMinAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
DoubleMinBufferAggregator - Class in org.apache.druid.query.aggregation
 
DoubleMinVectorAggregator - Class in org.apache.druid.query.aggregation
 
DoubleMinVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.DoubleMinVectorAggregator
 
doubleNilVectorAggregator() - Static method in class org.apache.druid.query.aggregation.any.NumericNilVectorAggregator
 
DoubleNumericColumnPartSerde - Class in org.apache.druid.segment.serde
 
DoubleNumericColumnPartSerde.SerializerBuilder - Class in org.apache.druid.segment.serde
 
DoubleNumericColumnPartSerdeV2 - Class in org.apache.druid.segment.serde
 
DoubleNumericColumnPartSerdeV2(ByteOrder, BitmapSerdeFactory, Serializer) - Constructor for class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2
 
DoubleNumericColumnPartSerdeV2.SerializerBuilder - Class in org.apache.druid.segment.serde
 
DoubleNumericColumnSupplier - Class in org.apache.druid.segment.serde
 
DoublesColumn - Class in org.apache.druid.segment.column
 
DoubleSearchColumnSelectorStrategy() - Constructor for class org.apache.druid.query.search.SearchQueryRunner.DoubleSearchColumnSelectorStrategy
 
DoubleSumAggregator - Class in org.apache.druid.query.aggregation
 
DoubleSumAggregator(BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.DoubleSumAggregator
 
DoubleSumAggregatorFactory - Class in org.apache.druid.query.aggregation
 
DoubleSumAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
DoubleSumAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
DoubleSumBufferAggregator - Class in org.apache.druid.query.aggregation
 
DoubleSumVectorAggregator - Class in org.apache.druid.query.aggregation
 
DoubleSumVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.DoubleSumVectorAggregator
 
DoubleTopNColumnAggregatesProcessor - Class in org.apache.druid.query.topn.types
 
DoubleTopNColumnAggregatesProcessor(Function<Object, Comparable<?>>) - Constructor for class org.apache.druid.query.topn.types.DoubleTopNColumnAggregatesProcessor
 
DoubleVectorValueMatcher - Class in org.apache.druid.query.filter.vector
 
DoubleVectorValueMatcher(VectorValueSelector) - Constructor for class org.apache.druid.query.filter.vector.DoubleVectorValueMatcher
 
DoubleWrappingDimensionSelector - Class in org.apache.druid.segment
 
DoubleWrappingDimensionSelector(BaseDoubleColumnValueSelector, ExtractionFn) - Constructor for class org.apache.druid.segment.DoubleWrappingDimensionSelector
 
DruidDefaultSerializersModule - Class in org.apache.druid.jackson
 
DruidDefaultSerializersModule() - Constructor for class org.apache.druid.jackson.DruidDefaultSerializersModule
 
DruidDoublePredicate - Interface in org.apache.druid.query.filter
Note: this is not a PublicApi or an ExtensionPoint of Druid.
DruidFloatPredicate - Interface in org.apache.druid.query.filter
Note: this is not a PublicApi or an ExtensionPoint of Druid.
DruidLongPredicate - Interface in org.apache.druid.query.filter
Note: this is not a PublicApi or an ExtensionPoint of Druid.
DruidMetrics - Class in org.apache.druid.query
 
DruidMetrics() - Constructor for class org.apache.druid.query.DruidMetrics
 
DruidPredicateFactory - Interface in org.apache.druid.query.filter
 
DruidProcessingConfig - Class in org.apache.druid.query
 
DruidProcessingConfig() - Constructor for class org.apache.druid.query.DruidProcessingConfig
 
Druids - Class in org.apache.druid.query
 
Druids.DataSourceMetadataQueryBuilder - Class in org.apache.druid.query
A Builder for DataSourceMetadataQuery.
Druids.ScanQueryBuilder - Class in org.apache.druid.query
A Builder for ScanQuery.
Druids.SearchQueryBuilder - Class in org.apache.druid.query
A Builder for SearchQuery.
Druids.SegmentMetadataQueryBuilder - Class in org.apache.druid.query
A Builder for SegmentMetadataQuery.
Druids.TimeBoundaryQueryBuilder - Class in org.apache.druid.query
A Builder for TimeBoundaryQuery.
Druids.TimeseriesQueryBuilder - Class in org.apache.druid.query
A Builder for TimeseriesQuery.
duplicate() - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
 
duplicate() - Method in class org.apache.druid.segment.data.DeltaLongEncodingReader
 
duplicate() - Method in class org.apache.druid.segment.data.LongsLongEncodingReader
 
duplicate() - Method in class org.apache.druid.segment.data.TableLongEncodingReader
 
duration(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
duration(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.getDuration() of the given query as dimension.
duration(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 

E

emit(ServiceEmitter) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
emit(ServiceEmitter) - Method in interface org.apache.druid.query.QueryMetrics
Emits all metrics, registered since the last emit() call on this QueryMetrics object.
emit(ServiceEmitter) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
emitCPUTimeMetric(ServiceEmitter) - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
emitCPUTimeMetric(ServiceEmitter, AtomicLong) - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
emitMetrics(ServiceEmitter, ServiceMetricEvent.Builder) - Method in interface org.apache.druid.query.ExecutorServiceMonitor.MetricEmitter
 
emitMetrics(ServiceEmitter, ServiceMetricEvent.Builder) - Method in class org.apache.druid.query.MetricsEmittingExecutorService
 
empty() - Static method in class org.apache.druid.collections.spatial.ImmutableRTree
 
empty() - Static method in class org.apache.druid.segment.column.RowSignature
 
EMPTY - Static variable in interface org.apache.druid.segment.data.BitmapValues
 
empty() - Static method in interface org.apache.druid.segment.data.IndexedInts
 
EMPTY - Static variable in class org.apache.druid.segment.data.VSizeLongSerde
 
EMPTY - Static variable in class org.apache.druid.segment.VirtualColumns
 
EMPTY_ARRAY - Static variable in interface org.apache.druid.query.topn.TopNAlgorithm
 
EMPTY_ARRAY - Static variable in interface org.apache.druid.segment.ColumnValueSelector
 
EMPTY_ROW_INDEX - Static variable in class org.apache.druid.segment.incremental.IncrementalIndexRow
 
EMPTY_VALUE_MATCHER_ARRAY - Static variable in interface org.apache.druid.query.filter.BooleanFilter
 
enclose() - Method in class org.apache.druid.collections.spatial.Node
 
enclose() - Method in class org.apache.druid.collections.spatial.Point
 
enclose(Node[]) - Static method in class org.apache.druid.collections.spatial.RTreeUtils
 
ensureSize(int) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
 
EntireLayoutColumnarDoublesSerializer - Class in org.apache.druid.segment.data
EntireLayoutColumnarDoublesSerializer(String, SegmentWriteOutMedium, ByteOrder) - Constructor for class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSerializer
 
EntireLayoutColumnarDoublesSupplier - Class in org.apache.druid.segment.data
 
EntireLayoutColumnarDoublesSupplier(int, ByteBuffer, ByteOrder) - Constructor for class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSupplier
 
EntireLayoutColumnarFloatsSerializer - Class in org.apache.druid.segment.data
EntireLayoutColumnarFloatsSupplier - Class in org.apache.druid.segment.data
 
EntireLayoutColumnarFloatsSupplier(int, ByteBuffer, ByteOrder) - Constructor for class org.apache.druid.segment.data.EntireLayoutColumnarFloatsSupplier
 
EntireLayoutColumnarLongsSerializer - Class in org.apache.druid.segment.data
EntireLayoutColumnarLongsSupplier - Class in org.apache.druid.segment.data
 
EntireLayoutColumnarLongsSupplier(int, CompressionFactory.LongEncodingReader) - Constructor for class org.apache.druid.segment.data.EntireLayoutColumnarLongsSupplier
 
Entry(T, Object[]) - Constructor for class org.apache.druid.query.groupby.epinephelinae.Grouper.Entry
 
EnumeratedTreeDistribution<T> - Class in org.apache.druid.segment.generator
EnumeratedDistrubtion's sample() method does a linear scan through the array of probabilities.
EnumeratedTreeDistribution(List<Pair<T, Double>>) - Constructor for class org.apache.druid.segment.generator.EnumeratedTreeDistribution
 
Equality - Class in org.apache.druid.segment.join
Represents a join condition between a left-hand-side expression (leftExpr) and a right-hand-side direct column access (rightColumn).
Equality(Expr, String) - Constructor for class org.apache.druid.segment.join.Equality
 
equals(Object) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
 
equals(Object) - Method in class org.apache.druid.collections.spatial.search.PolygonBound
 
equals(Object) - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
equals(Object) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.Histogram
 
equals(Object) - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
equals(Object) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
equals(Object) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
equals(Object) - Method in class org.apache.druid.query.BaseQuery
 
equals(Object) - Method in class org.apache.druid.query.BySegmentResultValueClass
 
equals(Object) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataResultValue
 
equals(Object) - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
equals(Object) - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
equals(Object) - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
equals(Object) - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
equals(Object) - Method in class org.apache.druid.query.dimension.PrefixFilteredDimensionSpec
 
equals(Object) - Method in class org.apache.druid.query.dimension.RegexFilteredDimensionSpec
 
equals(Object) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
 
equals(Object) - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.LowerExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
equals(Object) - Method in class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.StrlenExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.extraction.UpperExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.filter.AndDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.BoundDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.FalseDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.FilterTuning
 
equals(Object) - Method in class org.apache.druid.query.filter.InDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.InDimFilter.InFilterDruidPredicateFactory
 
equals(Object) - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
equals(Object) - Method in class org.apache.druid.query.filter.LikeDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
 
equals(Object) - Method in class org.apache.druid.query.filter.NotDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.OrDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.RegexDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
 
equals(Object) - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
equals(Object) - Method in class org.apache.druid.query.filter.TrueDimFilter
 
equals(Object) - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
 
equals(Object) - Method in class org.apache.druid.query.groupby.epinephelinae.Grouper.Entry
 
equals(Object) - Method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey
 
equals(Object) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
equals(Object) - Method in class org.apache.druid.query.groupby.having.AndHavingSpec
 
equals(Object) - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
equals(Object) - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
equals(Object) - Method in class org.apache.druid.query.groupby.having.EqualToHavingSpec
This method treats internal value as double mainly for ease of test.
equals(Object) - Method in class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
This method treats internal value as double mainly for ease of test.
equals(Object) - Method in class org.apache.druid.query.groupby.having.LessThanHavingSpec
This method treats internal value as double mainly for ease of test.
equals(Object) - Method in class org.apache.druid.query.groupby.having.NotHavingSpec
 
equals(Object) - Method in class org.apache.druid.query.groupby.having.OrHavingSpec
 
equals(Object) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
equals(Object) - Method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
equals(Object) - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
equals(Object) - Method in class org.apache.druid.query.groupby.ResultRow
 
equals(Object) - Method in class org.apache.druid.query.InlineDataSource
 
equals(Object) - Method in class org.apache.druid.query.JoinDataSource
 
equals(Object) - Method in class org.apache.druid.query.lookup.LookupConfig
 
equals(Object) - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
 
equals(Object) - Method in class org.apache.druid.query.lookup.LookupsState
 
equals(Object) - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
equals(Object) - Method in class org.apache.druid.query.LookupDataSource
 
equals(Object) - Method in class org.apache.druid.query.metadata.metadata.AllColumnIncluderator
 
equals(Object) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
equals(Object) - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
Best-effort equals method; relies on AggregatorFactory.equals, which is not guaranteed to be sanely implemented.
equals(Object) - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
equals(Object) - Method in class org.apache.druid.query.MetricValueExtractor
 
equals(Object) - Method in class org.apache.druid.query.ordering.StringComparators.AlphanumericComparator
 
equals(Object) - Method in class org.apache.druid.query.ordering.StringComparators.LexicographicComparator
 
equals(Object) - Method in class org.apache.druid.query.ordering.StringComparators.NumericComparator
 
equals(Object) - Method in class org.apache.druid.query.ordering.StringComparators.StrlenComparator
 
equals(Object) - Method in class org.apache.druid.query.ordering.StringComparators.VersionComparator
 
equals(Object) - Method in class org.apache.druid.query.planning.DataSourceAnalysis
 
equals(Object) - Method in class org.apache.druid.query.planning.PreJoinableClause
 
equals(Object) - Method in class org.apache.druid.query.QueryDataSource
 
equals(Object) - Method in class org.apache.druid.query.Result
 
equals(Object) - Method in class org.apache.druid.query.scan.ScanQuery
 
equals(Object) - Method in class org.apache.druid.query.scan.ScanQueryConfig
 
equals(Object) - Method in class org.apache.druid.query.scan.ScanResultValue
 
equals(Object) - Method in class org.apache.druid.query.search.AllSearchQuerySpec
 
equals(Object) - Method in class org.apache.druid.query.search.ContainsSearchQuerySpec
 
equals(Object) - Method in class org.apache.druid.query.search.FragmentSearchQuerySpec
 
equals(Object) - Method in class org.apache.druid.query.search.RegexSearchQuerySpec
 
equals(Object) - Method in class org.apache.druid.query.search.SearchHit
 
equals(Object) - Method in class org.apache.druid.query.search.SearchQuery
 
equals(Object) - Method in class org.apache.druid.query.search.SearchResultValue
 
equals(Object) - Method in class org.apache.druid.query.search.SearchSortSpec
 
equals(Object) - Method in class org.apache.druid.query.spec.MultipleIntervalSegmentSpec
 
equals(Object) - Method in class org.apache.druid.query.spec.MultipleSpecificSegmentSpec
 
equals(Object) - Method in class org.apache.druid.query.spec.SpecificSegmentSpec
 
equals(Object) - Method in class org.apache.druid.query.TableDataSource
 
equals(Object) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
equals(Object) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
 
equals(Object) - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
equals(Object) - Method in class org.apache.druid.query.topn.DimensionAndMetricValueExtractor
 
equals(Object) - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
equals(Object) - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
equals(Object) - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
equals(Object) - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
equals(Object) - Method in class org.apache.druid.query.topn.TopNQuery
 
equals(Object) - Method in class org.apache.druid.query.topn.TopNResultValue
 
equals(Object) - Method in class org.apache.druid.query.UnionDataSource
 
equals(Object) - Method in class org.apache.druid.segment.column.RowSignature
 
equals(Object) - Method in class org.apache.druid.segment.data.ConciseBitmapSerdeFactory
 
equals(Object) - Method in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
 
equals(Object) - Method in class org.apache.druid.segment.filter.AndFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.BoundFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.FalseFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.LikeFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.NotFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.OrFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.RegexFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.SearchQueryFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.SpatialFilter
 
equals(Object) - Method in class org.apache.druid.segment.filter.TrueFilter
 
equals(Object) - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
equals(Object) - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
 
equals(Object) - Method in class org.apache.druid.segment.IndexSpec
 
equals(Object) - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
 
equals(Object) - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysisKey
 
equals(Object) - Method in class org.apache.druid.segment.join.filter.JoinFilterSplit
 
equals(Object) - Method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
 
equals(Object) - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidate
 
equals(Object) - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidates
 
equals(Object) - Method in class org.apache.druid.segment.join.JoinableClause
 
equals(Object) - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
 
equals(Object) - Method in class org.apache.druid.segment.loading.BroadcastJoinableMMappedQueryableSegmentizerFactory
 
equals(Object) - Method in class org.apache.druid.segment.Metadata
 
equals(Object) - Method in class org.apache.druid.segment.TimeAndDimsPointer
 
equals(Object) - Method in class org.apache.druid.segment.transform.ExpressionTransform
 
equals(Object) - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
equals(Object) - Method in class org.apache.druid.segment.transform.TransformSpec
 
equals(Object) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
equals(Object) - Method in class org.apache.druid.segment.VirtualColumns
 
EqualToHavingSpec - Class in org.apache.druid.query.groupby.having
The "=" operator in a "having" clause.
EqualToHavingSpec(String, Number) - Constructor for class org.apache.druid.query.groupby.having.EqualToHavingSpec
 
Equiconditions - Class in org.apache.druid.segment.join.filter
 
Equiconditions(Map<String, Set<Expr>>) - Constructor for class org.apache.druid.segment.join.filter.Equiconditions
 
error(String) - Static method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
ERROR_CODE - Static variable in exception org.apache.druid.query.QueryUnsupportedException
 
estimateBytesInMemory() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
bytesInMemory estimates the size of IncrementalIndexRow key, it takes into account the timestamp(long), dims(Object Array) and dimensionDescsList(List).
estimateCardinality(Object, boolean) - Static method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
estimateEncodedKeyComponentSize(EncodedKeyComponentType) - Method in interface org.apache.druid.segment.DimensionIndexer
Gives the estimated size in bytes for the given key
estimateEncodedKeyComponentSize(Double) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
estimateEncodedKeyComponentSize(Float) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
estimateEncodedKeyComponentSize(Long) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
estimateEncodedKeyComponentSize(int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
estimateSelectivity(BitmapIndexSelector) - Method in interface org.apache.druid.query.filter.Filter
Estimate selectivity of this filter.
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.query.filter.InDimFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.AndFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.BoundFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.FalseFilter
 
estimateSelectivity(String, BitmapIndexSelector, Predicate<String>) - Static method in class org.apache.druid.segment.filter.Filters
Return an estimated selectivity for bitmaps of all values matching the given predicate.
estimateSelectivity(BitmapIndex, IntList, long) - Static method in class org.apache.druid.segment.filter.Filters
Return an estimated selectivity for bitmaps for the dimension values given by dimValueIndexes.
estimateSelectivity(Iterator<ImmutableBitmap>, long) - Static method in class org.apache.druid.segment.filter.Filters
Return an estimated selectivity for bitmaps given by an iterator.
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.LikeFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.NotFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.OrFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.SpatialFilter
 
estimateSelectivity(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.TrueFilter
 
eval(Expr.ObjectBinding) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorDynamicExpr
 
eval(Expr.ObjectBinding) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.AlwaysHavingSpec
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.AndHavingSpec
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.EqualToHavingSpec
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
 
eval(ResultRow) - Method in interface org.apache.druid.query.groupby.having.HavingSpec
Evaluates if a given row satisfies the having spec.
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.LessThanHavingSpec
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.NeverHavingSpec
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.NotHavingSpec
 
eval(ResultRow) - Method in class org.apache.druid.query.groupby.having.OrHavingSpec
 
eval(Row) - Method in interface org.apache.druid.segment.transform.RowFunction
 
execute(Runnable) - Method in class org.apache.druid.query.MetricsEmittingExecutorService
 
execute(Runnable) - Method in class org.apache.druid.query.PrioritizedExecutorService
 
execute(int) - Method in class org.apache.druid.query.search.CursorOnlyStrategy.CursorBasedExecutor
 
execute(int) - Method in class org.apache.druid.query.search.SearchQueryExecutor
 
execute(int) - Method in class org.apache.druid.query.search.UseIndexesStrategy.IndexOnlyExecutor
 
ExecutorServiceMonitor - Class in org.apache.druid.query
 
ExecutorServiceMonitor() - Constructor for class org.apache.druid.query.ExecutorServiceMonitor
 
ExecutorServiceMonitor.MetricEmitter - Interface in org.apache.druid.query
 
exists(String) - Method in class org.apache.druid.segment.VirtualColumns
Returns true if a virtual column exists with a particular columnName.
EXPRESSION - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
expression - Variable in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
expression - Variable in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
expression - Variable in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
ExpressionColumnValueSelector - Class in org.apache.druid.segment.virtual
Basic expression ColumnValueSelector.
ExpressionColumnValueSelector(Expr, Expr.ObjectBinding) - Constructor for class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
 
ExpressionDimFilter - Class in org.apache.druid.query.filter
 
ExpressionDimFilter(String, FilterTuning, ExprMacroTable) - Constructor for class org.apache.druid.query.filter.ExpressionDimFilter
 
ExpressionDimFilter(String, ExprMacroTable) - Constructor for class org.apache.druid.query.filter.ExpressionDimFilter
 
ExpressionFilter - Class in org.apache.druid.segment.filter
 
ExpressionFilter(Supplier<Expr>, FilterTuning) - Constructor for class org.apache.druid.segment.filter.ExpressionFilter
 
ExpressionMultiValueDimensionSelector - Class in org.apache.druid.segment.virtual
Basic multi-value dimension selector for an Expr evaluating ColumnValueSelector.
ExpressionMultiValueDimensionSelector(ColumnValueSelector<ExprEval>) - Constructor for class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
ExpressionPlan - Class in org.apache.druid.segment.virtual
 
ExpressionPlan.Trait - Enum in org.apache.druid.segment.virtual
 
ExpressionPlanner - Class in org.apache.druid.segment.virtual
 
ExpressionPostAggregator - Class in org.apache.druid.query.aggregation.post
 
ExpressionPostAggregator(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
Constructor for serialization.
ExpressionPostAggregator.Ordering - Enum in org.apache.druid.query.aggregation.post
 
ExpressionSelectors - Class in org.apache.druid.segment.virtual
 
ExpressionTransform - Class in org.apache.druid.segment.transform
 
ExpressionTransform(String, String, ExprMacroTable) - Constructor for class org.apache.druid.segment.transform.ExpressionTransform
 
ExpressionVectorObjectSelector - Class in org.apache.druid.segment.virtual
 
ExpressionVectorObjectSelector(ExprVectorProcessor<?>, Expr.VectorInputBinding) - Constructor for class org.apache.druid.segment.virtual.ExpressionVectorObjectSelector
 
ExpressionVectorSelectors - Class in org.apache.druid.segment.virtual
 
ExpressionVectorValueSelector - Class in org.apache.druid.segment.virtual
 
ExpressionVectorValueSelector(ExprVectorProcessor<?>, Expr.VectorInputBinding) - Constructor for class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
 
ExpressionVirtualColumn - Class in org.apache.druid.segment.virtual
 
ExpressionVirtualColumn(String, String, ValueType, ExprMacroTable) - Constructor for class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
ExpressionVirtualColumn(String, Expr, ValueType) - Constructor for class org.apache.druid.segment.virtual.ExpressionVirtualColumn
Constructor for creating an ExpressionVirtualColumn from a pre-parsed expression.
ExprUtils - Class in org.apache.druid.query.expression
 
ExprUtils() - Constructor for class org.apache.druid.query.expression.ExprUtils
 
ExtensionsConfig - Class in org.apache.druid.guice
 
ExtensionsConfig() - Constructor for class org.apache.druid.guice.ExtensionsConfig
 
extractedClass() - Method in interface org.apache.druid.segment.serde.ComplexMetricExtractor
 
extractFactoryName(List<AggregatorFactory>) - Static method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
ExtractionCacheHelper - Class in org.apache.druid.query.extraction
 
ExtractionCacheHelper() - Constructor for class org.apache.druid.query.extraction.ExtractionCacheHelper
 
ExtractionDimensionSpec - Class in org.apache.druid.query.dimension
 
ExtractionDimensionSpec(String, String, ValueType, ExtractionFn, ExtractionFn) - Constructor for class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
ExtractionDimensionSpec(String, String, ExtractionFn) - Constructor for class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
ExtractionDimensionSpec(String, String, ValueType, ExtractionFn) - Constructor for class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
ExtractionDimFilter - Class in org.apache.druid.query.filter
Deprecated.
ExtractionDimFilter(String, String, ExtractionFn, ExtractionFn) - Constructor for class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
ExtractionFn - Interface in org.apache.druid.query.extraction
An ExtractionFn is a function that can be used to transform the values of a column (typically a dimension).
extractionFn - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
ExtractionFn.ExtractionType - Enum in org.apache.druid.query.extraction
 
extractValue(InputRow, String) - Method in interface org.apache.druid.segment.serde.ComplexMetricExtractor
 
extractValue(InputRow, String, AggregatorFactory) - Method in interface org.apache.druid.segment.serde.ComplexMetricExtractor
 

F

factories() - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Return the AggregatorFactory objects that were used to create this object.
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
 
factorize(ColumnSelectorFactory, T) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
Creates an Aggregator to aggregate values from several rows, by using the provided selector.
factorize(ColumnSelectorFactory, ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
factorize(ColumnSelectorFactory, ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
factorize(ColumnSelectorFactory, ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
factorize() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerdeFactory
Create a new Grouper.KeySerde, which may be stateful.
factorize(DataSegment, File, boolean) - Method in class org.apache.druid.segment.loading.BroadcastJoinableMMappedQueryableSegmentizerFactory
 
factorize(DataSegment, File, boolean) - Method in class org.apache.druid.segment.loading.MMappedQueryableSegmentizerFactory
 
factorize(DataSegment, File, boolean) - Method in interface org.apache.druid.segment.loading.SegmentizerFactory
 
factorizeBuffered(ColumnSelectorFactory, List<AggregatorFactory>) - Static method in class org.apache.druid.query.aggregation.AggregatorAdapters
Create an adapters object based on BufferAggregator.
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory, T) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
Creates an BufferAggregator to aggregate values from several rows into a ByteBuffer.
factorizeBuffered(ColumnSelectorFactory, ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory, ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory, ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, List<AggregatorFactory>) - Static method in class org.apache.druid.query.aggregation.AggregatorAdapters
Create an adapters object based on VectorAggregator.
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Create a VectorAggregator based on the provided column selector factory.
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
 
factorizeVector(VectorColumnSelectorFactory, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
Creates a VectorAggregator to aggregate values from several rows into a ByteBuffer.
factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
factorizeWithDictionary(List<String>) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerdeFactory
Create a new Grouper.KeySerde with the given dictionary.
FalseDimFilter - Class in org.apache.druid.query.filter
 
FalseFilter - Class in org.apache.druid.segment.filter
 
FalseVectorMatcher - Class in org.apache.druid.query.filter.vector
 
FalseVectorMatcher(VectorSizeInspector) - Constructor for class org.apache.druid.query.filter.vector.FalseVectorMatcher
 
fetchAggregatorsFromCache(List<AggregatorFactory>, Iterator<Object>, boolean, CacheStrategy.AddToResultFunction) - Static method in interface org.apache.druid.query.CacheStrategy
Helper function used by TopN, GroupBy, Timeseries queries in CacheStrategy.pullFromCache(boolean).
FIELD_ACCESS - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
FieldAccessPostAggregator - Class in org.apache.druid.query.aggregation.post
 
FieldAccessPostAggregator(String, String) - Constructor for class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
fieldExpression - Variable in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
fieldExpression - Variable in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
fieldExpression - Variable in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
fieldName - Variable in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
fieldName - Variable in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
fieldName - Variable in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
fillBitmapsFromUnsortedEncodedKeyComponent(EncodedKeyComponentType, int, MutableBitmap[], BitmapFactory) - Method in interface org.apache.druid.segment.DimensionIndexer
Helper function for building bitmap indexes for integer-encoded dimensions.
fillBitmapsFromUnsortedEncodedKeyComponent(Double, int, MutableBitmap[], BitmapFactory) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
fillBitmapsFromUnsortedEncodedKeyComponent(Float, int, MutableBitmap[], BitmapFactory) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
fillBitmapsFromUnsortedEncodedKeyComponent(Long, int, MutableBitmap[], BitmapFactory) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
fillBitmapsFromUnsortedEncodedKeyComponent(int[], int, MutableBitmap[], BitmapFactory) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
filter(Iterable<ImmutablePoint>) - Method in interface org.apache.druid.collections.spatial.search.Bound
 
filter(Iterable<ImmutablePoint>) - Method in class org.apache.druid.collections.spatial.search.PolygonBound
 
filter(Iterable<ImmutablePoint>) - Method in class org.apache.druid.collections.spatial.search.RadiusBound
 
filter(Iterable<ImmutablePoint>) - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
Filter - Interface in org.apache.druid.query.filter
 
filter - Variable in class org.apache.druid.query.search.CursorOnlyStrategy.CursorBasedExecutor
 
filter - Variable in class org.apache.druid.query.search.SearchStrategy
 
FilterAnalysis(ImmutableBitmap, Filter) - Constructor for class org.apache.druid.segment.QueryableIndexStorageAdapter.FilterAnalysis
 
filterColumns(Set<String>) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
filterColumns(Set<String>) - Method in interface org.apache.druid.query.groupby.orderby.LimitSpec
Discard sorting columns not contained in given set.
filterColumns(Set<String>) - Method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
FILTERED_AGG_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
FilteredAggregator - Class in org.apache.druid.query.aggregation
 
FilteredAggregator(ValueMatcher, Aggregator) - Constructor for class org.apache.druid.query.aggregation.FilteredAggregator
 
FilteredAggregatorFactory - Class in org.apache.druid.query.aggregation
 
FilteredAggregatorFactory(AggregatorFactory, DimFilter) - Constructor for class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
FilteredAggregatorFactory(AggregatorFactory, DimFilter, String) - Constructor for class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
FilteredBufferAggregator - Class in org.apache.druid.query.aggregation
 
FilteredBufferAggregator(ValueMatcher, BufferAggregator) - Constructor for class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
FilteredOffset - Class in org.apache.druid.segment
 
FilteredVectorAggregator - Class in org.apache.druid.query.aggregation
 
FilteredVectorAggregator(VectorValueMatcher, VectorAggregator) - Constructor for class org.apache.druid.query.aggregation.FilteredVectorAggregator
 
FilteredVectorOffset - Class in org.apache.druid.segment.vector
 
filterMatchesNull(Filter) - Static method in class org.apache.druid.segment.filter.Filters
 
filterNulls(List<DimFilter>) - Static method in class org.apache.druid.query.filter.DimFilters
 
filters(DimFilter) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
filters(String, String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
filters(DimFilter) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
filters(String, String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
filters(DimFilter) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
filters(String, String) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
filters(String, String, String...) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
filters(DimFilter) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
filters(String, String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
filters(String, String, String...) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
filters(DimFilter) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
Filters - Class in org.apache.druid.segment.filter
 
Filters() - Constructor for class org.apache.druid.segment.filter.Filters
 
filterSegments(DataSourceMetadataQuery, List<T>) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
 
filterSegments(SegmentMetadataQuery, List<T>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
filterSegments(QueryType, List<T>) - Method in class org.apache.druid.query.QueryToolChest
This method is called to allow the query to prune segments that it does not believe need to actually be queried.
filterSegments(TimeBoundaryQuery, List<T>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
filterShards(DimFilter, Iterable<T>, Function<T, ShardSpec>) - Static method in class org.apache.druid.query.filter.DimFilterUtils
Filter the given iterable of objects by removing any object whose ShardSpec, obtained from the converter function, does not fit in the RangeSet of the dimFilter DimFilter.getDimensionRangeSet(String).
filterShards(DimFilter, Iterable<T>, Function<T, ShardSpec>, Map<String, Optional<RangeSet<String>>>) - Static method in class org.apache.druid.query.filter.DimFilterUtils
Filter the given iterable of objects by removing any object whose ShardSpec, obtained from the converter function, does not fit in the RangeSet of the dimFilter DimFilter.getDimensionRangeSet(String).
FilterTuning - Class in org.apache.druid.query.filter
FilterTuning(Boolean, Integer, Integer) - Constructor for class org.apache.druid.query.filter.FilterTuning
 
filterTuning - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
FINALIZE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
finalizeAnalysis(SegmentAnalysis) - Static method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
"Finalizes" the computation of an object.
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
FinalizeResultsQueryRunner<T> - Class in org.apache.druid.query
Query runner that applies QueryToolChest.makePostComputeManipulatorFn(Query, MetricManipulationFn) to the result stream.
FinalizeResultsQueryRunner(QueryRunner<T>, QueryToolChest<T, Query<T>>) - Constructor for class org.apache.druid.query.FinalizeResultsQueryRunner
 
finalizing() - Static method in class org.apache.druid.query.aggregation.MetricManipulatorFns
 
FINALIZING_FIELD_ACCESS - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
FinalizingFieldAccessPostAggregator - Class in org.apache.druid.query.aggregation.post
 
FinalizingFieldAccessPostAggregator(String, String) - Constructor for class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
find(Object) - Method in interface org.apache.druid.segment.join.table.IndexedTable.Index
Returns the list of row numbers where the column this Reader is based on contains 'key'.
findBucket(boolean, int, ByteBuffer, ByteBuffer, int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
Finds the bucket into which we should insert a key.
findBucket(int, Memory, int) - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Finds the bucket for a particular key.
findBucketWithAutoGrowth(ByteBuffer, int, Runnable) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
Find a bucket for a key, attempting to grow the table with adjustTableWhenFull() if possible.
findFactory(QueryType) - Method in class org.apache.druid.query.DefaultQueryRunnerFactoryConglomerate
 
findFactory(QueryType) - Method in interface org.apache.druid.query.QueryRunnerFactoryConglomerate
 
findNumComplexAggs(List<AggregatorFactory>) - Static method in class org.apache.druid.query.DruidMetrics
 
finish() - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
Signal that no more inputs are added.
firstTime - Variable in class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
firstValue - Variable in class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
firstWriteByte(MetaSerdeHelper.ByteFieldWriter<T>) - Static method in class org.apache.druid.segment.serde.MetaSerdeHelper
 
FIXED_BUCKET_HIST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
flatten(Filter) - Static method in class org.apache.druid.segment.filter.cnf.HiveCnfHelper
 
flattenAnd(Iterable<? extends Filter>) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
Flattens a list of AND nodes.
flattenOr(Iterable<? extends Filter>) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
Flattens a list of OR nodes.
FLOAT_ANY_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
FLOAT_COMPARATOR - Static variable in class org.apache.druid.segment.FloatDimensionIndexer
 
FLOAT_FIRST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
FLOAT_LAST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
FLOAT_MAX_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
FLOAT_MIN_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
FLOAT_SUM_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
FloatAnyAggregator - Class in org.apache.druid.query.aggregation.any
 
FloatAnyAggregator(BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.FloatAnyAggregator
 
FloatAnyAggregatorFactory - Class in org.apache.druid.query.aggregation.any
 
FloatAnyAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
FloatAnyBufferAggregator - Class in org.apache.druid.query.aggregation.any
 
FloatAnyBufferAggregator(BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
 
FloatAnyVectorAggregator - Class in org.apache.druid.query.aggregation.any
Vectorized implementation of the FloatAnyBufferAggregator
FloatAnyVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.FloatAnyVectorAggregator
 
FloatCardinalityAggregatorColumnSelectorStrategy - Class in org.apache.druid.query.aggregation.cardinality.types
If performance of this class appears to be a bottleneck for somebody, one simple way to improve it is to split it into two different classes, one that is used when NullHandling.replaceWithDefault() is false, and one - when it's true, moving this computation out of the tight loop
FloatCardinalityAggregatorColumnSelectorStrategy() - Constructor for class org.apache.druid.query.aggregation.cardinality.types.FloatCardinalityAggregatorColumnSelectorStrategy
 
FloatColumnSelector - Interface in org.apache.druid.segment
This interface is convenient for implementation of "float-sourcing" ColumnValueSelectors, it provides default implementations for all ColumnValueSelector's methods except BaseFloatColumnValueSelector.getFloat().
FloatColumnSerializer - Class in org.apache.druid.segment
 
FloatColumnSerializerV2 - Class in org.apache.druid.segment
Column Serializer for float column.
FloatDimensionHandler - Class in org.apache.druid.segment
 
FloatDimensionHandler(String) - Constructor for class org.apache.druid.segment.FloatDimensionHandler
 
FloatDimensionIndexer - Class in org.apache.druid.segment
 
FloatDimensionIndexer() - Constructor for class org.apache.druid.segment.FloatDimensionIndexer
 
FloatDimensionMergerV9 - Class in org.apache.druid.segment
 
FloatFirstAggregator - Class in org.apache.druid.query.aggregation.first
 
FloatFirstAggregator(BaseLongColumnValueSelector, BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.first.FloatFirstAggregator
 
FloatFirstAggregatorFactory - Class in org.apache.druid.query.aggregation.first
 
FloatFirstAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
FloatFirstBufferAggregator - Class in org.apache.druid.query.aggregation.first
 
FloatFirstBufferAggregator(BaseLongColumnValueSelector, BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.first.FloatFirstBufferAggregator
 
FloatGroupByColumnSelectorStrategy - Class in org.apache.druid.query.groupby.epinephelinae.column
 
FloatGroupByColumnSelectorStrategy() - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
FloatGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
FloatLastAggregator - Class in org.apache.druid.query.aggregation.last
 
FloatLastAggregator(BaseLongColumnValueSelector, BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.last.FloatLastAggregator
 
FloatLastAggregatorFactory - Class in org.apache.druid.query.aggregation.last
 
FloatLastAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
FloatLastBufferAggregator - Class in org.apache.druid.query.aggregation.last
 
FloatLastBufferAggregator(BaseLongColumnValueSelector, BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.last.FloatLastBufferAggregator
 
FloatMaxAggregator - Class in org.apache.druid.query.aggregation
 
FloatMaxAggregator(BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.FloatMaxAggregator
 
FloatMaxAggregatorFactory - Class in org.apache.druid.query.aggregation
 
FloatMaxAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
FloatMaxAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
FloatMaxBufferAggregator - Class in org.apache.druid.query.aggregation
 
FloatMaxVectorAggregator - Class in org.apache.druid.query.aggregation
 
FloatMaxVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.FloatMaxVectorAggregator
 
FloatMinAggregator - Class in org.apache.druid.query.aggregation
 
FloatMinAggregator(BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.FloatMinAggregator
 
FloatMinAggregatorFactory - Class in org.apache.druid.query.aggregation
 
FloatMinAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
FloatMinAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
FloatMinBufferAggregator - Class in org.apache.druid.query.aggregation
 
FloatMinVectorAggregator - Class in org.apache.druid.query.aggregation
 
FloatMinVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.FloatMinVectorAggregator
 
floatNilVectorAggregator() - Static method in class org.apache.druid.query.aggregation.any.NumericNilVectorAggregator
 
FloatNumericColumnPartSerde - Class in org.apache.druid.segment.serde
 
FloatNumericColumnPartSerde.SerializerBuilder - Class in org.apache.druid.segment.serde
 
FloatNumericColumnPartSerdeV2 - Class in org.apache.druid.segment.serde
 
FloatNumericColumnPartSerdeV2.SerializerBuilder - Class in org.apache.druid.segment.serde
 
FloatNumericColumnSupplier - Class in org.apache.druid.segment.serde
 
FloatNumericColumnSupplier(CompressedColumnarFloatsSupplier, ImmutableBitmap) - Constructor for class org.apache.druid.segment.serde.FloatNumericColumnSupplier
 
FloatsColumn - Class in org.apache.druid.segment.column
 
FloatSearchColumnSelectorStrategy() - Constructor for class org.apache.druid.query.search.SearchQueryRunner.FloatSearchColumnSelectorStrategy
 
FloatSumAggregator - Class in org.apache.druid.query.aggregation
 
FloatSumAggregator(BaseFloatColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.FloatSumAggregator
 
FloatSumAggregatorFactory - Class in org.apache.druid.query.aggregation
 
FloatSumAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
FloatSumAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
FloatSumBufferAggregator - Class in org.apache.druid.query.aggregation
 
FloatSumVectorAggregator - Class in org.apache.druid.query.aggregation
 
FloatSumVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.FloatSumVectorAggregator
 
FloatTopNColumnAggregatesProcessor - Class in org.apache.druid.query.topn.types
 
FloatTopNColumnAggregatesProcessor(Function<Object, Comparable<?>>) - Constructor for class org.apache.druid.query.topn.types.FloatTopNColumnAggregatesProcessor
 
FloatVectorValueMatcher - Class in org.apache.druid.query.filter.vector
 
FloatVectorValueMatcher(VectorValueSelector) - Constructor for class org.apache.druid.query.filter.vector.FloatVectorValueMatcher
 
FloatWrappingDimensionSelector - Class in org.apache.druid.segment
 
FloatWrappingDimensionSelector(BaseFloatColumnValueSelector, ExtractionFn) - Constructor for class org.apache.druid.segment.FloatWrappingDimensionSelector
 
FluentQueryRunner(QueryRunner<T>) - Constructor for class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
FluentQueryRunnerBuilder<T> - Class in org.apache.druid.query
 
FluentQueryRunnerBuilder(QueryToolChest<T, Query<T>>) - Constructor for class org.apache.druid.query.FluentQueryRunnerBuilder
 
FluentQueryRunnerBuilder.FluentQueryRunner - Class in org.apache.druid.query
 
flush() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
 
flush() - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
Flush the unwritten content to the current output.
flush() - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
flush() - Method in class org.apache.druid.segment.data.LongsLongEncodingWriter
 
flush() - Method in class org.apache.druid.segment.data.TableLongEncodingWriter
 
FN_NAME - Static variable in class org.apache.druid.query.expression.CaseInsensitiveContainsExprMacro
 
FN_NAME - Static variable in class org.apache.druid.query.expression.ContainsExprMacro
 
FN_NAME - Static variable in class org.apache.druid.query.expression.IPv4AddressMatchExprMacro
 
FN_NAME - Static variable in class org.apache.druid.query.expression.IPv4AddressParseExprMacro
 
FN_NAME - Static variable in class org.apache.druid.query.expression.IPv4AddressStringifyExprMacro
 
fold(ColumnValueSelector) - Method in interface org.apache.druid.query.aggregation.AggregateCombiner
Folds this AggregateCombiner's state value with the value of the given selector and saves it in this AggregateCombiner's state, e.
fold(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.cardinality.HyperLogLogCollectorAggregateCombiner
 
fold(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregateCombiner
 
fold(Histogram) - Method in class org.apache.druid.query.aggregation.Histogram
 
fold(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.last.StringLastAggregateCombiner
 
fold(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongSumAggregateCombiner
 
fold(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
fold(ColumnAnalysis) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
forDataSource(DataSource) - Static method in class org.apache.druid.query.planning.DataSourceAnalysis
 
forEach(IntConsumer) - Method in interface org.apache.druid.segment.data.IndexedInts
 
forExpression(String, String, ExprMacroTable) - Static method in class org.apache.druid.segment.join.JoinConditionAnalysis
Analyze a join condition.
forId(byte) - Static method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
 
forId(byte) - Static method in enum org.apache.druid.segment.data.CompressionStrategy
 
formatMessage(String) - Static method in exception org.apache.druid.segment.data.ColumnCapacityExceededException
 
formatRow(InputRow) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
forQuery(Query<?>) - Static method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
 
forValue(String) - Static method in enum org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
 
ForwardingRowIterator - Class in org.apache.druid.segment
Implementation of TransformableRowIterator that just delegates all methods to some baseIterator (adapter pattern).
ForwardingRowIterator(TransformableRowIterator) - Constructor for class org.apache.druid.segment.ForwardingRowIterator
 
fragments(List<String>) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
fragments(List<String>, boolean) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
FragmentSearchQuerySpec - Class in org.apache.druid.query.search
 
FragmentSearchQuerySpec(List<String>) - Constructor for class org.apache.druid.query.search.FragmentSearchQuerySpec
 
FragmentSearchQuerySpec(List<String>, boolean) - Constructor for class org.apache.druid.query.search.FragmentSearchQuerySpec
 
from(float[], float[], int) - Static method in class org.apache.druid.collections.spatial.search.PolygonBound
abscissa and ordinate contain the coordinates of polygon.
from(float[], float[]) - Static method in class org.apache.druid.collections.spatial.search.PolygonBound
 
from(String, Character) - Static method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
 
from(QueryRunner<T>) - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
fromArray(T[], ObjectStrategy<T>) - Static method in class org.apache.druid.segment.data.GenericIndexed
 
fromArray(int[]) - Static method in class org.apache.druid.segment.data.VSizeColumnarInts
 
fromArray(int[], int) - Static method in class org.apache.druid.segment.data.VSizeColumnarInts
 
fromByteBuffer(ByteBuffer, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
Deserialize a key from a buffer.
fromByteBuffer(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.CompressedColumnarDoublesSuppliers
 
fromByteBuffer(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.CompressedColumnarFloatsSupplier
 
fromByteBuffer(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
 
fromByteBuffer(ByteBuffer, ByteOrder, SmooshedFileMapper) - Static method in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
 
fromByteBuffer(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.CompressedColumnarLongsSupplier
 
fromByteBuffer(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
fromByteBuffer(ByteBuffer, ByteOrder, SmooshedFileMapper) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
fromByteBuffer(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier
 
fromByteBuffer(ByteBuffer, int) - Method in class org.apache.druid.segment.data.DecompressingByteBufferObjectStrategy
 
fromByteBuffer(ByteBuffer, int) - Method in class org.apache.druid.segment.data.ImmutableRTreeObjectStrategy
 
fromByteBuffer(ByteBuffer, int) - Method in interface org.apache.druid.segment.data.ObjectStrategy
Convert values from their underlying byte representation.
fromByteBuffer(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
 
fromByteBuffer(ByteBuffer, ByteOrder, SmooshedFileMapper) - Static method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
 
fromByteBuffer(ByteBuffer) - Static method in class org.apache.druid.segment.MetricHolder
 
fromByteBufferWithSize(ByteBuffer) - Method in interface org.apache.druid.segment.data.ObjectStrategy
Reads 4-bytes numBytes from the given buffer, and then delegates to ObjectStrategy.fromByteBuffer(ByteBuffer, int).
fromBytes(byte[]) - Static method in class org.apache.druid.query.aggregation.Histogram
 
fromBytes(ByteBuffer) - Static method in class org.apache.druid.query.aggregation.Histogram
 
fromBytes(byte[]) - Static method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
fromBytes(byte[], int, int) - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
Converts byte[] to intermediate representation of the aggregate.
fromIndexedInts(IndexedInts, int) - Static method in class org.apache.druid.segment.data.VSizeColumnarInts
 
fromInputRowParser(InputRowParser<T>) - Static method in class org.apache.druid.segment.transform.TransformSpec
 
fromIterable(Iterable<Object[]>, RowSignature) - Static method in class org.apache.druid.query.InlineDataSource
Creates an inline datasource from an Iterable.
fromIterable(Iterable<IndexedInts>, int, ByteOrder, CompressionStrategy, Closer) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier
 
fromIterable(Iterable<T>, ObjectStrategy<T>) - Static method in class org.apache.druid.segment.data.GenericIndexed
 
fromIterable(Iterable<IndexedInts>, int, int, ByteOrder, CompressionStrategy, Closer) - Static method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
 
fromIterable(Iterable<VSizeColumnarInts>) - Static method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
fromJsonArray(Object[]) - Static method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey
 
fromLegacyRow(Row, GroupByQuery) - Static method in class org.apache.druid.query.groupby.ResultRow
Create a row based on a legacy Row that was generated by a given GroupByQuery.
fromList(IntArrayList, int, ByteOrder, CompressionStrategy, Closer) - Static method in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
 
fromList(IntList, int, int, ByteOrder, CompressionStrategy, Closer) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
fromList(List<JoinableClause>) - Static method in class org.apache.druid.segment.join.filter.JoinableClauses
Wraps the provided list of pre-built JoinableClause.
fromRoaringBitmapIntIterator(IntIterator) - Static method in class org.apache.druid.segment.IntIteratorUtils
 
fromString(String) - Static method in enum org.apache.druid.query.groupby.orderby.OrderByColumnSpec.Direction
 
fromString(String) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
fromString(String) - Static method in enum org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
 
fromString(String) - Static method in class org.apache.druid.query.ordering.StringComparator
 
fromString(String) - Static method in enum org.apache.druid.query.QueryContexts.Vectorize
 
fromString(String) - Static method in enum org.apache.druid.query.scan.ScanQuery.Order
 
fromString(String) - Static method in enum org.apache.druid.query.scan.ScanQuery.ResultFormat
 
fromString(String) - Static method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingStrategy
 
fromString(String) - Static method in enum org.apache.druid.segment.data.CompressionStrategy
 
fromTo(int, int) - Static method in class org.apache.druid.segment.IntListUtils
 
fromValueSelector(ColumnValueSelector<ExprEval>, ExtractionFn) - Static method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
FunctionalExtraction - Class in org.apache.druid.query.extraction
Functional extraction uses a function to find the new value.
FunctionalExtraction(Function<String, String>, boolean, String, boolean) - Constructor for class org.apache.druid.query.extraction.FunctionalExtraction
The general constructor which handles most of the logic for extractions which can be expressed as a function of string-->string

G

generateHeaderFileName(String) - Static method in class org.apache.druid.segment.data.GenericIndexedWriter
 
generateRowValue() - Method in class org.apache.druid.segment.generator.ColumnValueGenerator
 
generateValueFileName(String, int) - Static method in class org.apache.druid.segment.data.GenericIndexedWriter
 
GeneratorBasicSchemas - Class in org.apache.druid.segment.generator
 
GeneratorBasicSchemas() - Constructor for class org.apache.druid.segment.generator.GeneratorBasicSchemas
 
GeneratorColumnSchema - Class in org.apache.druid.segment.generator
 
GeneratorColumnSchema(String, ValueType, boolean, int, Double, GeneratorColumnSchema.ValueDistribution, List<Object>, List<Double>, Integer, Integer, Double, Double, Double, Double, Double) - Constructor for class org.apache.druid.segment.generator.GeneratorColumnSchema
 
GeneratorColumnSchema.ValueDistribution - Enum in org.apache.druid.segment.generator
SEQUENTIAL: Generate integer or enumerated values in sequence.
GeneratorSchemaInfo - Class in org.apache.druid.segment.generator
 
GeneratorSchemaInfo(List<GeneratorColumnSchema>, List<AggregatorFactory>, Interval, boolean) - Constructor for class org.apache.druid.segment.generator.GeneratorSchemaInfo
 
Generic1AggPooledTopNScanner - Interface in org.apache.druid.query.topn
 
Generic1AggPooledTopNScannerPrototype - Class in org.apache.druid.query.topn
 
Generic1AggPooledTopNScannerPrototype() - Constructor for class org.apache.druid.query.topn.Generic1AggPooledTopNScannerPrototype
 
Generic2AggPooledTopNScanner - Interface in org.apache.druid.query.topn
 
Generic2AggPooledTopNScannerPrototype - Class in org.apache.druid.query.topn
 
Generic2AggPooledTopNScannerPrototype() - Constructor for class org.apache.druid.query.topn.Generic2AggPooledTopNScannerPrototype
 
GenericColumnSerializer<T> - Interface in org.apache.druid.segment
GenericColumnSerializer can be implemented in custom aggregator extensions that would like to take full control of column serialization.
GenericIndexed<T> - Class in org.apache.druid.segment.data
A generic, flat storage mechanism.
GenericIndexedBasedComplexColumn - Class in org.apache.druid.segment.column
Implementation of ComplexColumn to be used when complex column serialization is done by using GenericIndexed by using default implementations of "writeToXXX" methods in ComplexColumnSerializer
GenericIndexedBasedComplexColumn(String, GenericIndexed<?>) - Constructor for class org.apache.druid.segment.column.GenericIndexedBasedComplexColumn
 
GenericIndexedWriter<T> - Class in org.apache.druid.segment.data
Streams arrays of objects out in the binary format described by GenericIndexed
GenericIndexedWriter(SegmentWriteOutMedium, String, ObjectStrategy<T>) - Constructor for class org.apache.druid.segment.data.GenericIndexedWriter
 
GenericIndexedWriter(SegmentWriteOutMedium, String, ObjectStrategy<T>, int) - Constructor for class org.apache.druid.segment.data.GenericIndexedWriter
 
GenericQueryMetricsFactory - Interface in org.apache.druid.query
This factory is used for DI of custom QueryMetrics implementations for all query types, which don't (yet) need to emit custom dimensions and/or metrics, i.
get(int) - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
Returns true if the bit at position value is set
get(int) - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
get(int) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
get(int) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
get(int) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
get(int) - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
get() - Method in interface org.apache.druid.query.aggregation.Aggregator
 
get(ByteBuffer, int, int) - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Retrieve aggregation state from one of our aggregators.
get() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.LongAnyBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.NumericAnyVectorAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.NumericNilVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyVectorAggregator
 
get(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Returns the intermediate object representation of the given aggregate.
get() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.CountAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleMaxVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleMinVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleSumVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.FloatFirstBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.LongFirstBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatMaxVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.FloatMinAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatMinVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.FloatSumAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatSumVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.HistogramAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.DoubleLastBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.FloatLastBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.LongLastBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.LongMaxAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMaxVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.LongMinAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMinVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.LongSumAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongSumVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
get(ByteBuffer, int) - Static method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.NoopAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopVectorAggregator
 
get() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericVectorAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleLongBufferAggregator
 
get() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
get(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.VectorAggregator
get(ResponseContext.BaseKey) - Method in class org.apache.druid.query.context.ResponseContext
 
get(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferIntList
 
get(int) - Method in class org.apache.druid.query.groupby.ResultRow
 
get(String) - Method in interface org.apache.druid.query.lookup.LookupExtractorFactoryContainerProvider
Returns a lookup container for the provided lookupName, if it exists.
get(int) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
 
get() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarDoublesSupplier
 
get() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarFloatsSupplier
 
get() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarLongsSupplier
 
get(int) - Method in class org.apache.druid.segment.data.CachingIndexed
 
get(int) - Method in interface org.apache.druid.segment.data.ColumnarDoubles
 
get(double[], int, int) - Method in interface org.apache.druid.segment.data.ColumnarDoubles
 
get(double[], int[], int) - Method in interface org.apache.druid.segment.data.ColumnarDoubles
 
get(int) - Method in interface org.apache.druid.segment.data.ColumnarFloats
 
get(float[], int, int) - Method in interface org.apache.druid.segment.data.ColumnarFloats
 
get(float[], int[], int) - Method in interface org.apache.druid.segment.data.ColumnarFloats
 
get(int) - Method in interface org.apache.druid.segment.data.ColumnarLongs
 
get(long[], int, int) - Method in interface org.apache.druid.segment.data.ColumnarLongs
 
get(long[], int[], int) - Method in interface org.apache.druid.segment.data.ColumnarLongs
 
get(int) - Method in interface org.apache.druid.segment.data.ColumnarMultiInts
Returns the values at a given row index.
get() - Method in class org.apache.druid.segment.data.CompressedColumnarFloatsSupplier
 
get() - Method in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
 
get() - Method in class org.apache.druid.segment.data.CompressedColumnarLongsSupplier
 
get() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
get(int) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
 
get() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier
 
get() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSupplier
 
get() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarFloatsSupplier
 
get() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarLongsSupplier
 
get(int) - Method in class org.apache.druid.segment.data.GenericIndexed
 
get(int) - Method in class org.apache.druid.segment.data.GenericIndexedWriter
 
get(int) - Method in interface org.apache.druid.segment.data.Indexed
 
get(int) - Method in interface org.apache.druid.segment.data.IndexedInts
 
get(int[], int, int) - Method in interface org.apache.druid.segment.data.IndexedInts
 
get(int[], int[], int) - Method in interface org.apache.druid.segment.data.IndexedInts
 
get(int) - Method in class org.apache.druid.segment.data.ListIndexed
 
get(int) - Method in class org.apache.druid.segment.data.RangeIndexedInts
 
get(int) - Method in class org.apache.druid.segment.data.SingleIndexedInt
 
get(int) - Method in class org.apache.druid.segment.data.SliceIndexedInts
 
get() - Method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
 
get(int) - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
get() - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
get(int) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
get() - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
get(int) - Method in interface org.apache.druid.segment.data.VSizeLongSerde.LongDeserializer
 
get(int) - Method in class org.apache.druid.segment.data.ZeroIndexedInts
 
get() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
 
get(String) - Method in class org.apache.druid.segment.Metadata
 
get() - Method in class org.apache.druid.segment.serde.BitmapIndexColumnPartSupplier
 
get() - Method in class org.apache.druid.segment.serde.ComplexColumnPartSupplier
 
get() - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnSupplier
 
get() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnSupplier
 
get() - Method in class org.apache.druid.segment.serde.FloatNumericColumnSupplier
 
get() - Method in class org.apache.druid.segment.serde.LongNumericColumnSupplier
 
get() - Method in class org.apache.druid.segment.serde.SpatialIndexColumnPartSupplier
 
get(String) - Method in class org.apache.druid.segment.virtual.SingleInputBindings
 
getAbscissa() - Method in class org.apache.druid.collections.spatial.search.PolygonBound
 
getAddExtensionsToHadoopContainer() - Method in class org.apache.druid.guice.ExtensionsConfig
 
getAggIndexForOrderBy(OrderByColumnSpec, List<AggregatorFactory>) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
getAggregationName() - Method in class org.apache.druid.query.groupby.having.EqualToHavingSpec
 
getAggregationName() - Method in class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
 
getAggregationName() - Method in class org.apache.druid.query.groupby.having.LessThanHavingSpec
 
getAggregator() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getAggregators() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
getAggregators() - Method in class org.apache.druid.segment.Metadata
 
getAggregatorSizes() - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
 
getAggregatorSpecs() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getAggregatorSpecs() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
getAggregatorSpecs() - Method in class org.apache.druid.query.topn.TopNQuery
 
getAggs() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
 
getAggs() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getAggsArray() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
 
getAggsForRow(int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getAggsForRow(int) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getAggsForRow(int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getAggVal(AggregatorType, int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getAggVal(BufferAggregator, int, int) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getAggVal(Aggregator, int, int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getAllLookupNames() - Method in interface org.apache.druid.query.lookup.LookupExtractorFactoryContainerProvider
Returns the set of all lookup names that LookupExtractorFactoryContainerProvider.get(java.lang.String) can return containers for.
getAllRegisteredKeys() - Static method in enum org.apache.druid.query.context.ResponseContext.Key
getAnalysis() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
getAnalysisTypes() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
getAnalysisTypesCacheKey() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
getAppliedExpression() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
getApplyLimitPushDownFromContext() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getArea() - Method in class org.apache.druid.collections.spatial.Node
 
getArea() - Method in class org.apache.druid.collections.spatial.Point
 
getArg() - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
Exposed for Druid SQL: this is used by Expressions.toQueryGranularity.
getArray() - Method in class org.apache.druid.query.groupby.ResultRow
Get the backing array for this row (not a copy).
getArrayProvider() - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
 
getAsInt() - Method in class org.apache.druid.segment.RowNumCounter
 
getAt(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
getAtomicUpdateGroupSize() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
getAvailableColumns() - Method in interface org.apache.druid.segment.join.Joinable
Returns the list of columns that this Joinable offers.
getAvailableColumns() - Method in class org.apache.druid.segment.join.lookup.LookupJoinable
 
getAvailableColumns() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinable
 
getAvailableColumnsPrefixed() - Method in class org.apache.druid.segment.join.JoinableClause
Returns a list of columns from the underlying Joinable.getAvailableColumns() method, with our prefix (JoinableClause.getPrefix()) prepended.
getAvailableDimensions() - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getAvailableDimensions() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getAvailableDimensions() - Method in class org.apache.druid.segment.MMappedIndex
 
getAvailableDimensions() - Method in interface org.apache.druid.segment.QueryableIndex
 
getAvailableDimensions() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getAvailableDimensions() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getAvailableDimensions() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getAvailableDimensions() - Method in interface org.apache.druid.segment.StorageAdapter
 
getAvailableMetrics() - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getAvailableMetrics() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getAvailableMetrics() - Method in class org.apache.druid.segment.MMappedIndex
 
getAvailableMetrics() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getAvailableMetrics() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getAvailableMetrics() - Method in interface org.apache.druid.segment.StorageAdapter
 
getBaseColumns() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
 
getBaseDataSource() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns the base (bottom-leftmost) datasource.
getBaseExpressions() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
 
getBaseFilter() - Method in class org.apache.druid.segment.filter.NotFilter
 
getBaseObject() - Method in class org.apache.druid.query.MetricValueExtractor
 
getBaseObject() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
 
getBaseQuery() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns the bottommost (i.e.
getBaseQuerySegmentSpec() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns the QuerySegmentSpec that is associated with the base datasource, if any.
getBaseReadableOffset() - Method in class org.apache.druid.segment.BitmapOffset
 
getBaseReadableOffset() - Method in class org.apache.druid.segment.data.Offset
Returns the same offset ("this") or a readable "view" of this offset, which always returns the same value from ReadableOffset.getOffset(), as this offset.
getBaseReadableOffset() - Method in class org.apache.druid.segment.FilteredOffset
 
getBaseReadableOffset() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset
 
getBaseReadableOffset() - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
getBaseReadableOffset() - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
getBaseResultType() - Method in class org.apache.druid.query.QueryToolChest
 
getBaseSegment() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
getBaseTableDataSource() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
getBaseTableFilter() - Method in class org.apache.druid.segment.join.filter.JoinFilterSplit
 
getBaseUnionDataSource() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
getBatchSize() - Method in class org.apache.druid.query.scan.ScanQuery
 
getBitmap() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
getBitmap() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
getBitmap() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
getBitmap() - Method in class org.apache.druid.collections.spatial.Node
 
getBitmap() - Method in class org.apache.druid.collections.spatial.Point
 
getBitmap(int) - Method in interface org.apache.druid.segment.column.BitmapIndex
 
getBitmapFactory() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getBitmapFactory() - Method in class org.apache.druid.collections.spatial.RTree
 
getBitmapFactory() - Method in interface org.apache.druid.query.filter.BitmapIndexSelector
 
getBitmapFactory() - Method in interface org.apache.druid.segment.column.BitmapIndex
 
getBitmapFactory() - Method in class org.apache.druid.segment.ColumnSelectorBitmapIndexSelector
 
getBitmapFactory() - Method in interface org.apache.druid.segment.data.BitmapSerdeFactory
 
getBitmapFactory() - Method in class org.apache.druid.segment.data.ConciseBitmapSerdeFactory
 
getBitmapFactory() - Method in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
 
getBitmapFactoryForDimensions() - Method in interface org.apache.druid.segment.QueryableIndex
 
getBitmapFactoryForDimensions() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getBitmapIndex(String) - Method in interface org.apache.druid.query.filter.BitmapIndexSelector
 
getBitmapIndex(String, String) - Method in interface org.apache.druid.query.filter.BitmapIndexSelector
 
getBitmapIndex(BitmapIndexSelector) - Method in interface org.apache.druid.query.filter.Filter
Get a bitmap index, indicating rows that match this filter.
getBitmapIndex() - Method in interface org.apache.druid.segment.column.ColumnHolder
 
getBitmapIndex(String) - Method in class org.apache.druid.segment.ColumnSelectorBitmapIndexSelector
 
getBitmapIndex(String, String) - Method in class org.apache.druid.segment.ColumnSelectorBitmapIndexSelector
 
getBitmapIndex(BitmapIndexSelector, BitmapResultFactory<T>, Set<Filter>) - Static method in class org.apache.druid.segment.filter.AndFilter
 
getBitmapIndex(String, ColumnSelector) - Method in interface org.apache.druid.segment.VirtualColumn
Returns the BitmapIndex for efficient filtering on columns that support it.
getBitmapIndex(String, ColumnSelector) - Method in class org.apache.druid.segment.VirtualColumns
 
getBitmapIndexes() - Method in class org.apache.druid.segment.MMappedIndex
 
getBitmapIntersectCost() - Method in class org.apache.druid.query.search.SearchQueryDecisionHelper
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in interface org.apache.druid.query.filter.Filter
Get a (possibly wrapped) bitmap index, indicating rows that match this filter.
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.query.filter.InDimFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.AndFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.BoundFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.FalseFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.LikeFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.NotFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.OrFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.SpatialFilter
 
getBitmapResult(BitmapIndexSelector, BitmapResultFactory<T>) - Method in class org.apache.druid.segment.filter.TrueFilter
 
getBitmapSerdeFactory() - Method in class org.apache.druid.segment.IndexSpec
 
getBitmapSerdeFactory() - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
 
getBitmapSerdeFactory() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2
 
getBitmapSerdeFactory() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2
 
getBitmapSerdeFactory() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2
 
getBitmapValues(String, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getBitmapValues(String, int) - Method in interface org.apache.druid.segment.IndexableAdapter
 
getBitmapValues(String, int) - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getBitmapValues(String, int) - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getBitsForMax(long) - Static method in class org.apache.druid.segment.data.VSizeLongSerde
 
getBlockSize(int) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
Get the number of values that can be encoded into each block for the given block size in bytes
getBlockSize(int) - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
getBlockSize(int) - Method in class org.apache.druid.segment.data.LongsLongEncodingWriter
 
getBlockSize(int) - Method in class org.apache.druid.segment.data.TableLongEncodingWriter
 
getBound() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
getBound() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
getBreaks() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getBucketIterable() - Method in class org.apache.druid.query.vector.VectorCursorGranularizer
 
getBuckets() - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
getBufferGrouperInitialBuckets() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getBufferGrouperMaxLoadFactor() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getBufferGrouperMaxSize() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getBufferRecycler() - Static method in class org.apache.druid.segment.CompressedPools
 
getBySegmentResultType() - Method in class org.apache.druid.query.QueryToolChest
 
getByteBuf(ByteOrder) - Static method in class org.apache.druid.segment.CompressedPools
 
getByteOrder() - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
 
getByteOrder() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde
 
getByteOrder() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2
 
getByteOrder() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde
 
getByteOrder() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2
 
getByteOrder() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde
 
getByteOrder() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2
 
getBytesInMemory() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getBytesInMemory() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
getCacheKey() - Method in interface org.apache.druid.collections.spatial.search.Bound
 
getCacheKey() - Method in class org.apache.druid.collections.spatial.search.PolygonBound
 
getCacheKey() - Method in class org.apache.druid.collections.spatial.search.RadiusBound
 
getCacheKey() - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
getCacheKey() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getCacheKey() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
getCacheKey() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
getCacheKey() - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
getCacheKey() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
getCacheKey() - Method in class org.apache.druid.query.dimension.PrefixFilteredDimensionSpec
 
getCacheKey() - Method in class org.apache.druid.query.dimension.RegexFilteredDimensionSpec
 
getCacheKey() - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.LowerExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
getCacheKey() - Method in class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.StrlenExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.extraction.UpperExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.filter.AndDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
getCacheKey() - Method in class org.apache.druid.query.filter.FalseDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.InDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.NotDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.OrDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.filter.TrueDimFilter
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.AlwaysHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.AndHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.EqualToHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.LessThanHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.NeverHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.NotHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.having.OrHavingSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
getCacheKey() - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
getCacheKey() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.lookup.LookupExtractor
Create a cache key for use in results caching
getCacheKey() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
getCacheKey() - Method in class org.apache.druid.query.metadata.metadata.AllColumnIncluderator
 
getCacheKey() - Method in interface org.apache.druid.query.metadata.metadata.ColumnIncluderator
 
getCacheKey() - Method in class org.apache.druid.query.metadata.metadata.ListColumnIncluderator
 
getCacheKey() - Method in class org.apache.druid.query.metadata.metadata.NoneColumnIncluderator
 
getCacheKey() - Method in enum org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
 
getCacheKey() - Method in class org.apache.druid.query.ordering.StringComparator
 
getCacheKey() - Method in class org.apache.druid.query.ordering.StringComparators.AlphanumericComparator
 
getCacheKey() - Method in class org.apache.druid.query.ordering.StringComparators.LexicographicComparator
 
getCacheKey() - Method in class org.apache.druid.query.ordering.StringComparators.NumericComparator
 
getCacheKey() - Method in class org.apache.druid.query.ordering.StringComparators.StrlenComparator
 
getCacheKey() - Method in class org.apache.druid.query.ordering.StringComparators.VersionComparator
 
getCacheKey() - Method in class org.apache.druid.query.search.AllSearchQuerySpec
 
getCacheKey() - Method in class org.apache.druid.query.search.ContainsSearchQuerySpec
 
getCacheKey() - Method in class org.apache.druid.query.search.FragmentSearchQuerySpec
 
getCacheKey() - Method in class org.apache.druid.query.search.RegexSearchQuerySpec
 
getCacheKey() - Method in interface org.apache.druid.query.search.SearchQuerySpec
 
getCacheKey() - Method in class org.apache.druid.query.search.SearchSortSpec
 
getCacheKey() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
getCacheKey() - Method in class org.apache.druid.query.topn.AlphaNumericTopNMetricSpec
 
getCacheKey() - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
getCacheKey() - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
getCacheKey() - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
getCacheKey() - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
getCacheKey() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
getCacheKey() - Method in class org.apache.druid.segment.VirtualColumns
 
getCacheObjectClazz() - Method in interface org.apache.druid.query.CacheStrategy
Returns the class type of what is used in the cache
getCacheStrategy(DataSourceMetadataQuery) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
 
getCacheStrategy(GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
getCacheStrategy(SegmentMetadataQuery) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
getCacheStrategy(QueryType) - Method in class org.apache.druid.query.QueryToolChest
Returns a CacheStrategy to be used to load data into the cache and remove it from the cache.
getCacheStrategy(SearchQuery) - Method in class org.apache.druid.query.search.SearchQueryQueryToolChest
 
getCacheStrategy(TimeBoundaryQuery) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
getCacheStrategy(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
getCacheStrategy(TopNQuery) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
getCapabilities() - Method in interface org.apache.druid.segment.column.ColumnHolder
 
getCapabilities() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
 
getCapabilities(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getCapabilities() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.MetricDesc
 
getCapabilities(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getCapabilities(String) - Method in interface org.apache.druid.segment.IndexableAdapter
 
getCapabilities(String) - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getCapabilities(String) - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getCardinality() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
getCardinality() - Method in class org.apache.druid.query.topn.TopNParams
 
getCardinality(Selector) - Method in class org.apache.druid.query.topn.types.NullableNumericTopNColumnAggregatesProcessor
 
getCardinality(DimensionSelector) - Method in class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
 
getCardinality(ValueSelectorType) - Method in interface org.apache.druid.query.topn.types.TopNColumnAggregatesProcessor
Get value cardinality of underlying ColumnValueSelector
getCardinality() - Method in interface org.apache.druid.segment.column.BitmapIndex
 
getCardinality() - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
getCardinality() - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
getCardinality() - Method in interface org.apache.druid.segment.DimensionIndexer
Get the cardinality of this dimension's values.
getCardinality() - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
getCardinality() - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
getCardinality(String) - Method in interface org.apache.druid.segment.join.Joinable
Returns the cardinality of "columnName", or Joinable.CARDINALITY_UNKNOWN if not known.
getCardinality(String) - Method in class org.apache.druid.segment.join.lookup.LookupJoinable
 
getCardinality(String) - Method in class org.apache.druid.segment.join.table.IndexedTableJoinable
 
getCardinality() - Method in class org.apache.druid.segment.LongDimensionIndexer
 
getCardinality() - Method in class org.apache.druid.segment.StringDimensionIndexer
 
getCardinalityForArrayAggregation(GroupByQueryConfig, GroupByQuery, StorageAdapter, ByteBuffer) - Static method in class org.apache.druid.query.groupby.epinephelinae.GroupByQueryEngineV2
Returns the cardinality of array needed to do array-based aggregation, or -1 if array-based aggregation is impossible.
getChildren() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getChildren() - Method in class org.apache.druid.collections.spatial.ImmutablePoint
 
getChildren() - Method in class org.apache.druid.collections.spatial.Node
 
getChildren() - Method in class org.apache.druid.collections.spatial.Point
 
getChildren() - Method in interface org.apache.druid.query.DataSource
Returns datasources that this datasource depends on.
getChildren() - Method in class org.apache.druid.query.InlineDataSource
 
getChildren() - Method in class org.apache.druid.query.JoinDataSource
 
getChildren() - Method in class org.apache.druid.query.LookupDataSource
 
getChildren() - Method in class org.apache.druid.query.QueryDataSource
 
getChildren() - Method in class org.apache.druid.query.TableDataSource
 
getChildren() - Method in class org.apache.druid.query.UnionDataSource
 
getClazz() - Method in interface org.apache.druid.segment.column.ComplexColumn
 
getClazz() - Method in class org.apache.druid.segment.column.GenericIndexedBasedComplexColumn
 
getClazz() - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
getClazz() - Method in class org.apache.druid.segment.data.DecompressingByteBufferObjectStrategy
 
getClazz() - Method in class org.apache.druid.segment.data.GenericIndexed
 
getClazz() - Method in class org.apache.druid.segment.data.ImmutableRTreeObjectStrategy
 
getClazz() - Method in interface org.apache.druid.segment.data.ObjectStrategy
 
getCloser() - Method in class org.apache.druid.segment.writeout.OffHeapMemorySegmentWriteOutMedium
 
getCloser() - Method in class org.apache.druid.segment.writeout.OnHeapMemorySegmentWriteOutMedium
 
getCloser() - Method in interface org.apache.druid.segment.writeout.SegmentWriteOutMedium
Returns a closer of this SegmentWriteOutMedium, which is closed in this SegmentWriteOutMedium's close() method.
getCloser() - Method in class org.apache.druid.segment.writeout.TmpFileSegmentWriteOutMedium
 
getColumn() - Method in interface org.apache.druid.segment.column.ColumnHolder
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.column.RowSignature
 
getColumnCapabilities(String) - Method in interface org.apache.druid.segment.ColumnInspector
Returns capabilities of a particular column.
getColumnCapabilities(String) - Method in interface org.apache.druid.segment.ColumnSelectorFactory
Returns capabilities of a particular column, if known.
getColumnCapabilities() - Method in interface org.apache.druid.segment.DimensionIndexer
 
getColumnCapabilities() - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
getColumnCapabilities() - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
getColumnCapabilities() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.join.filter.AllNullColumnSelectorFactory
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getColumnCapabilities(String) - Method in interface org.apache.druid.segment.join.Joinable
Returns capabilities for one of this Joinable's columns.
getColumnCapabilities(String) - Method in class org.apache.druid.segment.join.lookup.LookupColumnSelectorFactory
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.join.lookup.LookupJoinable
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.join.table.IndexedTableColumnSelectorFactory
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.join.table.IndexedTableJoinable
 
getColumnCapabilities() - Method in class org.apache.druid.segment.LongDimensionIndexer
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getColumnCapabilities(ColumnSelector, String) - Static method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.RowBasedColumnSelectorFactory
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getColumnCapabilities(String) - Method in interface org.apache.druid.segment.StorageAdapter
Returns capabilities of a particular column, if known.
getColumnCapabilities() - Method in class org.apache.druid.segment.StringDimensionIndexer
 
getColumnCapabilities(String) - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
 
getColumnCapabilities(String) - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
Returns capabilities of a particular column, or null if the column doesn't exist.
getColumnCapabilities(String) - Method in class org.apache.druid.segment.virtual.VirtualizedColumnSelectorFactory
 
getColumnCapabilities(ColumnInspector, String) - Method in class org.apache.druid.segment.VirtualColumns
 
getColumnCapabilitiesWithFallback(ColumnInspector, String) - Method in class org.apache.druid.segment.VirtualColumns
 
getColumnFromJoinIfExists(String) - Method in class org.apache.druid.segment.join.filter.JoinableClauses
 
getColumnHolder(String) - Method in interface org.apache.druid.segment.ColumnSelector
 
getColumnHolder(String) - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getColumnInspectorForIndex(ColumnSelector) - Static method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getColumnName(int) - Method in class org.apache.druid.segment.column.RowSignature
Returns the name of the column at position columnNumber.
getColumnNames() - Method in class org.apache.druid.query.InlineDataSource
 
getColumnNames() - Method in class org.apache.druid.segment.AbstractIndex
 
getColumnNames() - Method in class org.apache.druid.segment.column.RowSignature
Returns a list of column names in the order they appear in this signature.
getColumnNames() - Method in interface org.apache.druid.segment.ColumnSelector
 
getColumnNames() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getColumnNames() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getColumns() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
getColumns() - Method in class org.apache.druid.query.metadata.metadata.ListColumnIncluderator
 
getColumns() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
getColumns() - Method in class org.apache.druid.query.scan.ScanQuery
 
getColumns() - Method in class org.apache.druid.query.scan.ScanResultValue
 
getColumns() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getColumnSchemas() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
 
getColumnSelectorFactory() - Method in interface org.apache.druid.segment.Cursor
 
getColumnSelectorFactory() - Method in interface org.apache.druid.segment.join.JoinMatcher
Returns a factory for reading columns from the Joinable that correspond to matched rows.
getColumnSelectorFactory() - Method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
 
getColumnSelectorFactory() - Method in class org.apache.druid.segment.join.PostJoinCursor
 
getColumnSelectorFactory() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinMatcher
 
getColumnSelectorFactory() - Method in class org.apache.druid.segment.RowBasedCursor
 
getColumnSelectorFactory() - Method in interface org.apache.druid.segment.vector.VectorCursor
Returns a vectorized column selector factory.
getColumnSelectorStrategy() - Method in class org.apache.druid.query.ColumnSelectorPlus
 
getColumnType(String) - Method in class org.apache.druid.segment.column.RowSignature
Returns the type of the column named columnName, or empty if the type is unknown or the column does not exist.
getColumnType(int) - Method in class org.apache.druid.segment.column.RowSignature
Returns the type of the column at position columnNumber, or empty if the type is unknown.
getColumnTypeName(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getColumnTypeName(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getColumnTypeName(String) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getColumnTypeName(String) - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getColumnTypeName(String) - Method in interface org.apache.druid.segment.StorageAdapter
Like ColumnCapabilities.getType(), but may return a more descriptive string for complex columns.
getColumnTypes() - Method in class org.apache.druid.query.InlineDataSource
 
getCombinedParseException(InputRow, List<String>, List<String>) - Static method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Returns an AggregatorFactory that can be used to combine the output of aggregators from this factory.
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getCombiningFactory() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
getComparator() - Method in interface org.apache.druid.query.aggregation.PostAggregator
 
getComparator() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getComparator() - Method in class org.apache.druid.query.search.SearchSortSpec
 
getComparator(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.AlphaNumericTopNMetricSpec
 
getComparator(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
getComparator(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
getComparator(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
getComparator(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
getComparator(List<AggregatorFactory>, List<PostAggregator>) - Method in interface org.apache.druid.query.topn.TopNMetricSpec
 
getComparatorForDimName(DefaultLimitSpec, String) - Static method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Get the complex type name of the intermediate type for this aggregator.
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getComplexTypeName() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getCompressor() - Method in enum org.apache.druid.segment.data.CompressionStrategy
 
getCompressRunOnSerialization() - Method in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
 
getCondition() - Method in class org.apache.druid.query.JoinDataSource
 
getCondition() - Method in class org.apache.druid.query.planning.PreJoinableClause
 
getCondition() - Method in class org.apache.druid.segment.join.JoinableClause
The join condition.
getConditionAnalysis() - Method in class org.apache.druid.query.JoinDataSource
 
getConfig() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
getConstantValue() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
getContainer() - Method in class org.apache.druid.segment.Metadata
 
getContext() - Method in class org.apache.druid.query.BaseQuery
 
getContext() - Method in class org.apache.druid.query.DefaultQueryConfig
 
getContext() - Method in interface org.apache.druid.query.Query
 
getContext() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getContextBoolean(String, boolean) - Method in class org.apache.druid.query.BaseQuery
 
getContextBoolean(String, boolean) - Method in interface org.apache.druid.query.Query
 
getContextBoolean(String, boolean) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getContextSortByDimsFirst() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getContextValue(String) - Method in class org.apache.druid.query.BaseQuery
 
getContextValue(String, ContextType) - Method in class org.apache.druid.query.BaseQuery
 
getContextValue(String) - Method in interface org.apache.druid.query.Query
 
getContextValue(String, ContextType) - Method in interface org.apache.druid.query.Query
 
getContextValue(String) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getContextValue(String, ContextType) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getCoordinatorFetchRetries() - Method in class org.apache.druid.query.lookup.LookupConfig
 
getCoordinatorRetryDelay() - Method in class org.apache.druid.query.lookup.LookupConfig
 
getCoords() - Method in class org.apache.druid.collections.spatial.ImmutablePoint
 
getCoords() - Method in class org.apache.druid.collections.spatial.Point
 
getCoords() - Method in class org.apache.druid.collections.spatial.search.RadiusBound
 
getCorrelatedColumnValues(String, String, String, long, boolean) - Method in interface org.apache.druid.segment.join.Joinable
Searches a column from this Joinable for a particular value, finds rows that match, and returns values of a second column for those rows.
getCorrelatedColumnValues(String, String, String, long, boolean) - Method in class org.apache.druid.segment.join.lookup.LookupJoinable
 
getCorrelatedColumnValues(String, String, String, long, boolean) - Method in class org.apache.druid.segment.join.table.IndexedTableJoinable
 
getCorrelatedValuesMap() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
 
getCorrelationsByDirectFilteringColumn() - Method in class org.apache.druid.segment.join.filter.JoinFilterCorrelations
 
getCorrelationsByDirectFilteringColumn() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getCorrelationsByFilteringColumn() - Method in class org.apache.druid.segment.join.filter.JoinFilterCorrelations
 
getCorrelationsByFilteringColumn() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getCount() - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
 
getCount() - Method in class org.apache.druid.query.search.SearchHit
 
getCurrent() - Method in class org.apache.druid.query.lookup.LookupsState
 
getCurrentVectorSize() - Method in class org.apache.druid.query.filter.vector.BaseVectorValueMatcher
 
getCurrentVectorSize() - Method in class org.apache.druid.query.filter.vector.FalseVectorMatcher
 
getCurrentVectorSize() - Method in class org.apache.druid.query.filter.vector.TrueVectorMatcher
 
getCurrentVectorSize() - Method in class org.apache.druid.segment.vector.BaseDoubleVectorValueSelector
 
getCurrentVectorSize() - Method in class org.apache.druid.segment.vector.BaseFloatVectorValueSelector
 
getCurrentVectorSize() - Method in class org.apache.druid.segment.vector.BaseLongVectorValueSelector
 
getCurrentVectorSize() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
getCurrentVectorSize() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
getCurrentVectorSize() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getCurrentVectorSize() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
getCurrentVectorSize() - Method in interface org.apache.druid.segment.vector.VectorSizeInspector
Returns the current vector size for this cursor.
getCurrentVectorSize() - Method in class org.apache.druid.segment.virtual.ExpressionVectorObjectSelector
 
getCurrentVectorSize() - Method in class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
 
getCursor() - Method in class org.apache.druid.query.topn.TopNParams
 
getData() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getDataInterval() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
 
getDataInterval() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getDataInterval() - Method in class org.apache.druid.segment.IncrementalIndexSegment
 
getDataInterval() - Method in interface org.apache.druid.segment.IndexableAdapter
 
getDataInterval() - Method in class org.apache.druid.segment.join.HashJoinSegment
 
getDataInterval() - Method in class org.apache.druid.segment.MMappedIndex
 
getDataInterval() - Method in interface org.apache.druid.segment.QueryableIndex
 
getDataInterval() - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getDataInterval() - Method in class org.apache.druid.segment.QueryableIndexSegment
 
getDataInterval() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
getDataInterval() - Method in class org.apache.druid.segment.RowBasedSegment
 
getDataInterval() - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getDataInterval() - Method in interface org.apache.druid.segment.Segment
 
getDataInterval() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getDataSource() - Method in class org.apache.druid.query.BaseQuery
 
getDataSource() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns the topmost datasource: the original one passed to DataSourceAnalysis.forDataSource(DataSource).
getDataSource() - Method in class org.apache.druid.query.planning.PreJoinableClause
 
getDataSource() - Method in interface org.apache.druid.query.Query
 
getDataSource() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getDataSources() - Method in class org.apache.druid.query.UnionDataSource
 
getDecisionHelper(QueryableIndex) - Method in class org.apache.druid.query.search.SearchStrategy
 
getDecompressor() - Method in enum org.apache.druid.segment.data.CompressionStrategy
 
getDefaultAnalysisTypes() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryConfig
 
getDefaultHistory() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryConfig
 
getDefaultStrategy() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getDelegate() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getDelegate() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
getDelegate() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
getDelegate() - Method in class org.apache.druid.query.context.ConcurrentResponseContext
 
getDelegate() - Method in class org.apache.druid.query.context.DefaultResponseContext
 
getDelegate() - Method in class org.apache.druid.query.context.ResponseContext
 
getDelegate() - Method in class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
getDelegate() - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
getDependentFields() - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
getDependentFields() - Method in interface org.apache.druid.query.aggregation.PostAggregator
 
getDescriptor() - Method in class org.apache.druid.query.spec.SpecificSegmentSpec
 
getDescriptors() - Method in class org.apache.druid.query.spec.MultipleSpecificSegmentSpec
 
getDeserializer(int, ByteBuffer, int) - Static method in class org.apache.druid.segment.data.VSizeLongSerde
 
getDeserializer() - Method in interface org.apache.druid.segment.serde.ColumnPartSerde
 
getDeserializer() - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde
 
getDeserializer() - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
 
getDeserializer() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde
 
getDeserializer() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2
 
getDeserializer() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde
 
getDeserializer() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2
 
getDeserializer() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde
 
getDeserializer() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2
 
getDictionary() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
Return the dictionary of this KeySerde.
getDimColumn(String) - Method in class org.apache.druid.segment.MMappedIndex
 
getDimension() - Method in class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
getDimension() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
getDimension() - Method in interface org.apache.druid.query.dimension.DimensionSpec
 
getDimension() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
getDimension() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
getDimension() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getDimension() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
getDimension() - Method in class org.apache.druid.query.filter.InDimFilter
 
getDimension() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
getDimension() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
getDimension() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
getDimension() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
getDimension() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
getDimension() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
getDimension() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
getDimension() - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
getDimension() - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
getDimension() - Method in class org.apache.druid.query.search.SearchHit
 
getDimension() - Method in class org.apache.druid.segment.filter.SelectorFilter
 
getDimension(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getDimension(String) - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
getDimensionCardinality(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getDimensionCardinality(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getDimensionCardinality(String) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getDimensionCardinality(String) - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getDimensionCardinality(String) - Method in interface org.apache.druid.segment.StorageAdapter
Returns the number of distinct values for the given column if known, or Integer.MAX_VALUE if unknown, e.
getDimensionComparator() - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
getDimensionCompression() - Method in class org.apache.druid.segment.IndexSpec
 
getDimensionHandlers() - Method in interface org.apache.druid.segment.QueryableIndex
 
getDimensionHandlers() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getDimensionIndex(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getDimensionName() - Method in interface org.apache.druid.segment.DimensionHandler
Get the name of the column associated with this handler.
getDimensionName() - Method in class org.apache.druid.segment.DoubleDimensionHandler
 
getDimensionName() - Method in class org.apache.druid.segment.FloatDimensionHandler
 
getDimensionName() - Method in class org.apache.druid.segment.LongDimensionHandler
 
getDimensionName() - Method in class org.apache.druid.segment.StringDimensionHandler
 
getDimensionNames() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getDimensionNames() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getDimensionNames() - Method in interface org.apache.druid.segment.IndexableAdapter
 
getDimensionNames() - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getDimensionNames() - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getDimensionOrder() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.AndDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
getDimensionRangeSet(String) - Method in interface org.apache.druid.query.filter.DimFilter
Returns a RangeSet that represents the possible range of the input dimension for this DimFilter.This is applicable to filters that use dimensions such as select, in, bound, and logical filters such as and, or, not.
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.FalseDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.InDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.LikeDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.NotDimFilter
There are some special cases involving null that require special casing for And and Or instead of simply taking the complement Example 1 : "NOT ( [0,INF) OR null)" The inside of NOT would evaluate to null, and the complement would also be null.
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.OrDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.RegexDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.TrueDimFilter
 
getDimensions() - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
getDimensions() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getDimensions() - Method in class org.apache.druid.query.search.SearchQuery
 
getDimensions() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getDimensions() - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
getDimensionSchema() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getDimensionsFilter() - Method in class org.apache.druid.query.search.SearchQuery
 
getDimensionsFilter() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
getDimensionsFilter() - Method in class org.apache.druid.query.topn.TopNQuery
 
getDimensionSpec() - Method in class org.apache.druid.query.topn.TopNQuery
 
getDimensionsSpec() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
 
getDimensionsSpec() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
 
getDimensionValue(String) - Method in class org.apache.druid.query.topn.DimensionAndMetricValueExtractor
 
getDimensionValues(String) - Method in interface org.apache.druid.query.filter.BitmapIndexSelector
 
getDimensionValues(String) - Method in class org.apache.druid.segment.ColumnSelectorBitmapIndexSelector
 
getDimFilter() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getDimFilter() - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
getDimIndexForOrderBy(OrderByColumnSpec, List<DimensionSpec>) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
getDims() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
 
getDimSelector() - Method in class org.apache.druid.query.topn.TopNParams
 
getDimValIndex() - Method in class org.apache.druid.query.topn.DimValHolder
 
getDimValue() - Method in class org.apache.druid.query.topn.DimValHolder
 
getDimValueLookup(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getDimValueLookup(String) - Method in interface org.apache.druid.segment.IndexableAdapter
 
getDimValueLookup(String) - Method in class org.apache.druid.segment.MMappedIndex
 
getDimValueLookup(String) - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getDimValueLookup(String) - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getDirection() - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
getDirectory() - Method in class org.apache.druid.guice.ExtensionsConfig
 
getDistributionType() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getDouble() - Method in interface org.apache.druid.query.aggregation.Aggregator
The default implementation casts Aggregator.getFloat() to double.
getDouble() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.LongAnyBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
 
getDouble(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Returns the double representation of the given aggregate byte array Converts the given byte buffer representation into the intermediate aggregate value.
getDouble() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.CountAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.FloatFirstBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.LongFirstBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.FloatMinAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.FloatSumAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.HistogramAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.DoubleLastBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.FloatLastBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.LongLastBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.LongMaxAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.LongMinAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.LongSumAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.NoopAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
getDouble() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleLongBufferAggregator
 
getDouble() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
getDouble() - Method in interface org.apache.druid.segment.BaseDoubleColumnValueSelector
 
getDouble() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
 
getDouble() - Method in interface org.apache.druid.segment.DimensionSelector
Deprecated.
This method is marked as deprecated in DimensionSelector to minimize the probability of accidental calling. "Polymorphism" of DimensionSelector should be used only when operating on ColumnValueSelector objects.
getDouble() - Method in interface org.apache.druid.segment.FloatColumnSelector
Deprecated.
This method is marked as deprecated in FloatColumnSelector to minimize the probability of accidental calling. "Polymorphism" of FloatColumnSelector should be used only when operating on ColumnValueSelector objects.
getDouble(int) - Method in interface org.apache.druid.segment.historical.HistoricalColumnSelector
 
getDouble() - Method in class org.apache.druid.segment.join.PossiblyNullColumnValueSelector
 
getDouble() - Method in class org.apache.druid.segment.join.table.IndexedTableColumnValueSelector
 
getDouble() - Method in interface org.apache.druid.segment.LongColumnSelector
Deprecated.
This method is marked as deprecated in LongColumnSelector to minimize the probability of accidental calling. "Polymorphism" of LongColumnSelector should be used only when operating on ColumnValueSelector objects.
getDouble() - Method in class org.apache.druid.segment.NilColumnValueSelector
always returns 0, if NullHandling.replaceWithDefault() is set to true, or always throws an exception, if NullHandling.replaceWithDefault() is set to false.
getDouble() - Method in class org.apache.druid.segment.ObjectColumnSelector
Deprecated.
This method is marked as deprecated in ObjectColumnSelector to minimize the probability of accidental calling. "Polymorphism" of ObjectColumnSelector should be used only when operating on ColumnValueSelector objects.
getDouble() - Method in class org.apache.druid.segment.selector.settable.SettableDoubleColumnValueSelector
 
getDouble() - Method in class org.apache.druid.segment.selector.settable.SettableValueDoubleColumnValueSelector
 
getDouble() - Method in class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
 
getDouble() - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
 
getDouble() - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
 
getDoubleGenericColumnPartSerde(ByteOrder) - Static method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde
 
getDoubleGenericColumnPartSerde(ByteOrder, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2
 
getDoubleMetric(String) - Method in class org.apache.druid.query.MetricValueExtractor
 
getDoublePredicateSupplier() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getDoubleSerializer(String, SegmentWriteOutMedium, String, ByteOrder, CompressionStrategy) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
getDoubleSupplier(int, int, ByteBuffer, ByteOrder, CompressionStrategy) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
getDoubleVector() - Method in class org.apache.druid.segment.vector.BaseFloatVectorValueSelector
 
getDoubleVector() - Method in class org.apache.druid.segment.vector.BaseLongVectorValueSelector
 
getDoubleVector() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getDoubleVector() - Method in interface org.apache.druid.segment.vector.VectorValueSelector
Get the current vector, casting to doubles as necessary.
getDoubleVector() - Method in class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
 
getDuration() - Method in class org.apache.druid.query.BaseQuery
 
getDuration() - Method in interface org.apache.druid.query.Query
 
getDuration() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getEnableJoinFilterPushDown(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getEnableJoinFilterRewrite(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getEnableJoinFilterRewriteValueColumnFilters(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getEnableLookupSyncOnStartup() - Method in class org.apache.druid.query.lookup.LookupConfig
 
getEnableParallelMerges(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getEnclosingArea(Node, Node) - Static method in class org.apache.druid.collections.spatial.RTreeUtils
 
getEncodedValueSelectorComparator() - Method in interface org.apache.druid.segment.DimensionHandler
Returns a comparator that knows how to compare ColumnValueSelector of the assumed dimension type, corresponding to this DimensionHandler.
getEncodedValueSelectorComparator() - Method in class org.apache.druid.segment.DoubleDimensionHandler
 
getEncodedValueSelectorComparator() - Method in class org.apache.druid.segment.FloatDimensionHandler
 
getEncodedValueSelectorComparator() - Method in class org.apache.druid.segment.LongDimensionHandler
 
getEncodedValueSelectorComparator() - Method in class org.apache.druid.segment.StringDimensionHandler
 
getEndDouble() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getEndInt() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getEndOffset() - Method in class org.apache.druid.query.vector.VectorCursorGranularizer
 
getEndRootPartitionId() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
getEnumeratedProbabilities() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getEnumeratedValues() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getEquiconditions() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getEquiConditions() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
Return a list of equi-conditions (see class-level javadoc).
getErrorClass() - Method in exception org.apache.druid.query.QueryException
 
getErrorCode() - Method in exception org.apache.druid.query.QueryException
 
getErrorMessage() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
getEscape() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
getEvents() - Method in class org.apache.druid.query.scan.ScanResultValue
 
getExactLongFromDecimalString(String) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
Convert a string representing a decimal value to a long.
getExcludeList() - Method in class org.apache.druid.guice.ModulesConfig
 
getExecutionPlan(SearchQuery, Segment) - Method in class org.apache.druid.query.search.AutoStrategy
 
getExecutionPlan(SearchQuery, Segment) - Method in class org.apache.druid.query.search.CursorOnlyStrategy
 
getExecutionPlan(SearchQuery, Segment) - Method in class org.apache.druid.query.search.SearchStrategy
 
getExecutionPlan(SearchQuery, Segment) - Method in class org.apache.druid.query.search.UseIndexesStrategy
 
getExpansionCost(Node, Point) - Static method in class org.apache.druid.collections.spatial.RTreeUtils
 
getExpr() - Method in class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
getExpr() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
getExpression() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
getExpression() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
getExpression() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
getExpression() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
getExpression() - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
getExpression() - Method in class org.apache.druid.segment.transform.ExpressionTransform
 
getExpression() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
getExpression() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
getExtractionFn() - Method in class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
getExtractionFn() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
getExtractionFn() - Method in interface org.apache.druid.query.dimension.DimensionSpec
Deprecated.
getExtractionFn() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
getExtractionFn() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
getExtractionFn() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getExtractionFn() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
getExtractionFn() - Method in class org.apache.druid.query.filter.InDimFilter
 
getExtractionFn() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
getExtractionFn() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
getExtractionFn() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
getExtractionFn() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
getExtractionFn() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
getExtractionFn() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
getExtractionFn() - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
getExtractionFns() - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
getExtractionType() - Method in interface org.apache.druid.query.extraction.ExtractionFn
A dim extraction can be of one of two types, renaming or rebucketing.
getExtractionType() - Method in class org.apache.druid.query.extraction.FunctionalExtraction
 
getExtractionType() - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.LowerExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.StrlenExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.extraction.UpperExtractionFn
 
getExtractionType() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
getExtractor() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
 
getExtractor() - Method in class org.apache.druid.query.aggregation.hyperloglog.PreComputedHyperUniquesSerde
 
getExtractor() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringSerde
 
getExtractor() - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
 
getFacts() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getFacts() - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getFacts() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getField() - Method in class org.apache.druid.query.filter.NotDimFilter
 
getField(T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.ByteFieldWriter
 
getField(T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.IntFieldWriter
 
getFieldName() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
getFieldName() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
getFieldName() - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
getFieldName() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
getFieldName() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
getFieldNames() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getFieldNames() - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
getFields() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getFields() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
getFields() - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
getFields() - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
getFields() - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
getFields() - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
getFields() - Method in class org.apache.druid.query.filter.AndDimFilter
 
getFields() - Method in class org.apache.druid.query.filter.OrDimFilter
 
getFile() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
 
getFileMapper() - Method in class org.apache.druid.segment.column.ColumnBuilder
 
getFileMapper() - Method in class org.apache.druid.segment.MMappedIndex
 
getFileMapper() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getFilter() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getFilter() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
getFilter() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getFilter() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
getFilter() - Method in interface org.apache.druid.query.Query
 
getFilter() - Method in class org.apache.druid.query.scan.ScanQuery
 
getFilter() - Method in class org.apache.druid.query.search.SearchQuery
 
getFilter() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getFilter() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
getFilter() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
getFilter() - Method in class org.apache.druid.query.topn.TopNQuery
 
getFilter() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysisKey
 
getFilter() - Method in class org.apache.druid.segment.transform.TransformSpec
 
getFilterRewriteMaxSize() - Method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
 
getFilters() - Method in interface org.apache.druid.query.filter.BooleanFilter
 
getFilters() - Method in class org.apache.druid.segment.filter.AndFilter
 
getFilters() - Method in class org.apache.druid.segment.filter.OrFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.InDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
getFilterTuning() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Get the type for the final form of this this aggregator, i.e.
getFinalizedType() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
actual type is HistogramVisual
getFinalizedType() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
 
getFinalizedType() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getFirstEventTimestamp(ScanQuery.ResultFormat) - Method in class org.apache.druid.query.scan.ScanResultValue
 
getFloat() - Method in interface org.apache.druid.query.aggregation.Aggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.LongAnyBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
 
getFloat(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Returns the float representation of the given aggregate byte array Converts the given byte buffer representation into the intermediate aggregate value.
getFloat() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.CountAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.FloatFirstBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.LongFirstBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.FloatMinAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.FloatSumAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.HistogramAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.DoubleLastBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.FloatLastBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.LongLastBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.LongMaxAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.LongMinAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.LongSumAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.NoopAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
getFloat() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleLongBufferAggregator
 
getFloat() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
getFloat() - Method in interface org.apache.druid.segment.BaseFloatColumnValueSelector
 
getFloat() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
 
getFloat() - Method in interface org.apache.druid.segment.DimensionSelector
Deprecated.
This method is marked as deprecated in DimensionSelector to minimize the probability of accidental calling. "Polymorphism" of DimensionSelector should be used only when operating on ColumnValueSelector objects.
getFloat() - Method in interface org.apache.druid.segment.DoubleColumnSelector
Deprecated.
This method is marked as deprecated in DoubleColumnSelector to minimize the probability of accidental calling. "Polymorphism" of DoubleColumnSelector should be used only when operating on ColumnValueSelector objects.
getFloat() - Method in class org.apache.druid.segment.join.PossiblyNullColumnValueSelector
 
getFloat() - Method in class org.apache.druid.segment.join.table.IndexedTableColumnValueSelector
 
getFloat() - Method in interface org.apache.druid.segment.LongColumnSelector
Deprecated.
This method is marked as deprecated in LongColumnSelector to minimize the probability of accidental calling. "Polymorphism" of LongColumnSelector should be used only when operating on ColumnValueSelector objects.
getFloat() - Method in class org.apache.druid.segment.NilColumnValueSelector
always returns 0.0f, if NullHandling.replaceWithDefault() is set to true, or always throws an exception, if NullHandling.replaceWithDefault() is set to false.
getFloat() - Method in class org.apache.druid.segment.ObjectColumnSelector
Deprecated.
This method is marked as deprecated in ObjectColumnSelector to minimize the probability of accidental calling. "Polymorphism" of ObjectColumnSelector should be used only when operating on ColumnValueSelector objects.
getFloat() - Method in class org.apache.druid.segment.selector.settable.SettableFloatColumnValueSelector
 
getFloat() - Method in class org.apache.druid.segment.selector.settable.SettableValueFloatColumnValueSelector
 
getFloat() - Method in class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
 
getFloat() - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
 
getFloat() - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
 
getFloatMetric(String) - Method in class org.apache.druid.query.MetricValueExtractor
 
getFloatPredicateSupplier() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getFloatSerializer(String, SegmentWriteOutMedium, String, ByteOrder, CompressionStrategy) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
getFloatSupplier(int, int, ByteBuffer, ByteOrder, CompressionStrategy) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
getFloatVector() - Method in class org.apache.druid.segment.vector.BaseDoubleVectorValueSelector
 
getFloatVector() - Method in class org.apache.druid.segment.vector.BaseLongVectorValueSelector
 
getFloatVector() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getFloatVector() - Method in interface org.apache.druid.segment.vector.VectorValueSelector
Get the current vector, casting to floats as necessary.
getFloatVector() - Method in class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
 
getFnAggregate() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getFnCombine() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getFnName() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
getFnReset() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getFormat() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
getFormat() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
getFullResult() - Method in class org.apache.druid.query.context.ResponseContext.SerializationResult
 
getFunction() - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
getFunction() - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
getFunction() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
getGran() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
 
getGranularity() - Method in class org.apache.druid.query.BaseQuery
 
getGranularity() - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
Exposed for Druid SQL: this is used by Expressions.toQueryGranularity.
getGranularity() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
getGranularity() - Method in interface org.apache.druid.query.Query
 
getGranularity() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
getGroupingKeySize() - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
Return the size, in bytes, of this dimension's values in the grouping key.
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.DoubleGroupByVectorColumnSelector
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.FloatGroupByVectorColumnSelector
 
getGroupingKeySize() - Method in interface org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnSelector
Get the size in bytes of the key parts generated by this column.
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.LongGroupByVectorColumnSelector
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableDoubleGroupByVectorColumnSelector
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableFloatGroupByVectorColumnSelector
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableLongGroupByVectorColumnSelector
 
getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.SingleValueStringGroupByVectorColumnSelector
 
getGrowthCount() - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
getGrowthCount() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
getHadoopContainerDruidClasspath() - Method in class org.apache.druid.guice.ExtensionsConfig
 
getHadoopDependenciesDir() - Method in class org.apache.druid.guice.ExtensionsConfig
 
getHandler() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
 
getHandlerFromCapabilities(String, ColumnCapabilities, DimensionSchema.MultiValueHandling) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
getHavingSpec() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getHavingSpec() - Method in class org.apache.druid.query.groupby.having.NotHavingSpec
 
getHavingSpecs() - Method in class org.apache.druid.query.groupby.having.AndHavingSpec
 
getHavingSpecs() - Method in class org.apache.druid.query.groupby.having.OrHavingSpec
 
getHeapIndexForOffset(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper.BufferGrouperOffsetHeapIndexUpdater
 
getHeapSize() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
getHost() - Method in exception org.apache.druid.query.QueryException
 
getId() - Method in class org.apache.druid.query.BaseQuery
 
getId() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
getId() - Method in interface org.apache.druid.query.Query
 
getId() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getId() - Method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
 
getId() - Method in enum org.apache.druid.segment.data.CompressionStrategy
 
getId() - Method in class org.apache.druid.segment.IncrementalIndexSegment
 
getId() - Method in class org.apache.druid.segment.join.HashJoinSegment
 
getId() - Method in class org.apache.druid.segment.QueryableIndexSegment
 
getId() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
getId() - Method in class org.apache.druid.segment.RowBasedSegment
 
getId() - Method in interface org.apache.druid.segment.Segment
 
getId() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
getId() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
getId() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
getId() - Method in interface org.apache.druid.segment.vector.ReadableVectorOffset
Returns an integer that uniquely identifies the current position of the offset.
getImmutableBitmap() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getIndex() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
getIndex() - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
getIndex(String) - Method in interface org.apache.druid.segment.column.BitmapIndex
Returns the index of "value" in this BitmapIndex, or (-(insertion point) - 1) if the value is not present, in the manner of Arrays.binarySearch.
getIndex() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
 
getIndex() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.MetricDesc
 
getIndexer() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
 
getInitialOffset() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getInstance() - Static method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
getIntermediateCombineDegree() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getInterval() - Method in interface org.apache.druid.query.BySegmentResultValue
 
getInterval() - Method in class org.apache.druid.query.BySegmentResultValueClass
 
getInterval() - Method in class org.apache.druid.query.search.BySegmentSearchResultValue
 
getInterval() - Method in class org.apache.druid.query.topn.BySegmentTopNResultValue
 
getInterval() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getInterval() - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getInterval() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getInterval() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getInterval() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getInterval() - Method in interface org.apache.druid.segment.StorageAdapter
 
getIntervals() - Method in class org.apache.druid.query.BaseQuery
 
getIntervals() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
getIntervals() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
getIntervals() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
getIntervals() - Method in interface org.apache.druid.query.Query
 
getIntervals() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getIntervals() - Method in class org.apache.druid.query.spec.MultipleIntervalSegmentSpec
 
getIntervals() - Method in class org.apache.druid.query.spec.MultipleSpecificSegmentSpec
 
getIntervals() - Method in interface org.apache.druid.query.spec.QuerySegmentSpec
 
getIntervals() - Method in class org.apache.druid.query.spec.SpecificSegmentSpec
 
getIntrospectHandler() - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
 
getIsInputHyperUnique() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getJoinable() - Method in class org.apache.druid.segment.join.JoinableClause
The right-hand Joinable.
getJoinableClause() - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidate
 
getJoinableClauses() - Method in class org.apache.druid.segment.join.filter.JoinableClauses
 
getJoinableClauses() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getJoinableClauses() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysisKey
 
getJoinColumn() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
 
getJoinFilterRewriteMaxSize(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getJoinTableFilter() - Method in class org.apache.druid.segment.join.filter.JoinFilterSplit
 
getJoinType() - Method in class org.apache.druid.query.JoinDataSource
 
getJoinType() - Method in class org.apache.druid.query.planning.PreJoinableClause
 
getJoinType() - Method in class org.apache.druid.segment.join.JoinableClause
The type of join: LEFT, RIGHT, INNER, or FULL.
getKey() - Method in class org.apache.druid.query.groupby.epinephelinae.Grouper.Entry
 
getKey() - Method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey
 
getKey() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getKeyBufferPosition() - Method in class org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorPlus
 
getKeyColumns() - Method in class org.apache.druid.segment.loading.BroadcastJoinableMMappedQueryableSegmentizerFactory
 
getLane(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getLastRowIndex() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getLastRowIndex() - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getLastRowIndex() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getLeft() - Method in class org.apache.druid.query.JoinDataSource
 
getLeftExpr() - Method in class org.apache.druid.segment.join.Equality
 
getLength() - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
getLength() - Method in interface org.apache.druid.segment.column.ColumnHolder
 
getLength() - Method in interface org.apache.druid.segment.column.ComplexColumn
 
getLength() - Method in class org.apache.druid.segment.column.GenericIndexedBasedComplexColumn
 
getLength() - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
getLengthOfEncodedKeyComponent(EncodedKeyComponentType) - Method in interface org.apache.druid.segment.DimensionHandler
Given an key component representing a single set of row value(s) for this dimension as an Object, return the length of the key component after appropriate type-casting.
getLengthOfEncodedKeyComponent(Double) - Method in class org.apache.druid.segment.DoubleDimensionHandler
 
getLengthOfEncodedKeyComponent(Float) - Method in class org.apache.druid.segment.FloatDimensionHandler
 
getLengthOfEncodedKeyComponent(Long) - Method in class org.apache.druid.segment.LongDimensionHandler
 
getLengthOfEncodedKeyComponent(int[]) - Method in class org.apache.druid.segment.StringDimensionHandler
 
getLexicographicMergedDimensions(List<IndexableAdapter>) - Static method in interface org.apache.druid.segment.IndexMerger
 
getLhsExprs(String) - Method in class org.apache.druid.segment.join.filter.Equiconditions
 
getLimit() - Method in interface org.apache.druid.collections.spatial.search.Bound
 
getLimit() - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
getLimit() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
getLimit() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
Limit for this query; behaves like SQL "LIMIT".
getLimit() - Method in class org.apache.druid.query.search.SearchQuery
 
getLimit() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
getLimitSpec() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getLoadList() - Method in class org.apache.druid.guice.ExtensionsConfig
 
getLocale() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
getLong() - Method in interface org.apache.druid.query.aggregation.Aggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.LongAnyBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
 
getLong(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Returns the long representation of the given aggregate byte array Converts the given byte buffer representation into the intermediate aggregate value.
getLong() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.CountAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.DoubleFirstBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.FloatFirstBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.LongFirstBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.FloatMinAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.FloatSumAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.HistogramAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.DoubleLastBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.FloatLastBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.LongLastBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.LongMaxAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.LongMinAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.LongSumAggregateCombiner
 
getLong() - Method in class org.apache.druid.query.aggregation.LongSumAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.NoopAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
getLong() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleLongBufferAggregator
 
getLong() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
getLong(int) - Method in class org.apache.druid.query.groupby.ResultRow
 
getLong() - Method in interface org.apache.druid.segment.BaseLongColumnValueSelector
 
getLong() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
 
getLong() - Method in interface org.apache.druid.segment.DimensionSelector
Deprecated.
This method is marked as deprecated in DimensionSelector to minimize the probability of accidental calling. "Polymorphism" of DimensionSelector should be used only when operating on ColumnValueSelector objects.
getLong() - Method in interface org.apache.druid.segment.DoubleColumnSelector
Deprecated.
This method is marked as deprecated in DoubleColumnSelector to minimize the probability of accidental calling. "Polymorphism" of DoubleColumnSelector should be used only when operating on ColumnValueSelector objects.
getLong() - Method in interface org.apache.druid.segment.FloatColumnSelector
Deprecated.
This method is marked as deprecated in FloatColumnSelector to minimize the probability of accidental calling. "Polymorphism" of FloatColumnSelector should be used only when operating on ColumnValueSelector objects.
getLong() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
 
getLong() - Method in class org.apache.druid.segment.join.PossiblyNullColumnValueSelector
 
getLong() - Method in class org.apache.druid.segment.join.table.IndexedTableColumnValueSelector
 
getLong() - Method in class org.apache.druid.segment.NilColumnValueSelector
always returns 0L, if NullHandling.replaceWithDefault() is set to true, or always throws an exception, if NullHandling.replaceWithDefault() is set to false.
getLong() - Method in class org.apache.druid.segment.ObjectColumnSelector
Deprecated.
This method is marked as deprecated in ObjectColumnSelector to minimize the probability of accidental calling. "Polymorphism" of ObjectColumnSelector should be used only when operating on ColumnValueSelector objects.
getLong() - Method in class org.apache.druid.segment.selector.settable.SettableLongColumnValueSelector
 
getLong() - Method in class org.apache.druid.segment.selector.settable.SettableValueLongColumnValueSelector
 
getLong() - Method in class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
 
getLong() - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
 
getLong() - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
 
getLongEncoding() - Method in class org.apache.druid.segment.IndexSpec
 
getLongestSharedDimOrder(List<IndexableAdapter>) - Static method in interface org.apache.druid.segment.IndexMerger
 
getLongMetric(String) - Method in class org.apache.druid.query.MetricValueExtractor
 
getLongPredicateSupplier() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getLongSerializer(String, SegmentWriteOutMedium, String, ByteOrder, CompressionFactory.LongEncodingStrategy, CompressionStrategy) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
getLongSingleValueRow(int) - Method in class org.apache.druid.segment.column.DoublesColumn
 
getLongSingleValueRow(int) - Method in class org.apache.druid.segment.column.FloatsColumn
 
getLongSingleValueRow(int) - Method in class org.apache.druid.segment.column.LongsColumn
 
getLongSingleValueRow(int) - Method in interface org.apache.druid.segment.column.NumericColumn
 
getLongSupplier(int, int, ByteBuffer, ByteOrder, CompressionFactory.LongEncodingFormat, CompressionStrategy) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
getLongVector() - Method in class org.apache.druid.segment.vector.BaseDoubleVectorValueSelector
 
getLongVector() - Method in class org.apache.druid.segment.vector.BaseFloatVectorValueSelector
 
getLongVector() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getLongVector() - Method in interface org.apache.druid.segment.vector.VectorValueSelector
Get the current vector, casting to longs as necessary.
getLongVector() - Method in class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
 
getLookup() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
getLookup() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
getLookup() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
getLookupExtractorFactory() - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
 
getLookupName() - Method in class org.apache.druid.query.LookupDataSource
 
getLookupStartRetries() - Method in class org.apache.druid.query.lookup.LookupConfig
 
getLower() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getMap() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
getMarkedPointer() - Method in class org.apache.druid.segment.ForwardingRowIterator
 
getMarkedPointer() - Method in interface org.apache.druid.segment.TransformableRowIterator
Returns a pointer to the row, that was the current row when RowIterator.mark() was called for the last time.
getMaxBuckets() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
getMaxCardinalityToUseBitmapIndex() - Method in class org.apache.druid.query.filter.FilterTuning
 
getMaxCoordinates() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getMaxCoordinates() - Method in class org.apache.druid.collections.spatial.Node
 
getMaxCoords() - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
getMaxDictionarySize() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerdeFactory
Return max dictionary size threshold.
getMaxIngestedEventTime() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataResultValue
 
getMaxIngestedEventTime() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMaxIngestedEventTime() - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getMaxIngestedEventTime() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getMaxIngestedEventTime() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getMaxIngestedEventTime() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getMaxIngestedEventTime() - Method in interface org.apache.druid.segment.StorageAdapter
 
getMaxIntermediateRows() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Returns the maximum size that this aggregator will require in bytes for intermediate storage of results.
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getMaxIntermediateSizeWithNulls() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Returns the maximum size that this aggregator will require in bytes for intermediate storage of results.
getMaxIntermediateSizeWithNulls() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
 
getMaxIntermediateSizeWithNulls() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getMaxMergingDictionarySize() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getMaxOnDiskStorage() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getMaxQueuedBytes(Query<T>, long) - Static method in class org.apache.druid.query.QueryContexts
 
getMaxResults() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getMaxRowsQueuedForOrdering() - Method in class org.apache.druid.query.scan.ScanQuery
 
getMaxRowsQueuedForOrdering() - Method in class org.apache.druid.query.scan.ScanQueryConfig
 
getMaxScatterGatherBytes(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getMaxSearchLimit() - Method in class org.apache.druid.query.search.SearchQueryConfig
 
getMaxSegmentPartitionsOrderedInMemory() - Method in class org.apache.druid.query.scan.ScanQuery
 
getMaxSegmentPartitionsOrderedInMemory() - Method in class org.apache.druid.query.scan.ScanQueryConfig
 
getMaxSize() - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
getMaxStringBytes() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getMaxStringBytes() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getMaxStringBytes() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getMaxSubqueryRows(Query<T>, int) - Static method in class org.apache.druid.query.QueryContexts
 
getMaxTime() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
 
getMaxTime() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMaxTime() - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getMaxTime() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getMaxTime() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getMaxTime() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getMaxTime() - Method in interface org.apache.druid.segment.StorageAdapter
 
getMaxValue() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
getMaxValue() - Method in interface org.apache.druid.segment.DimensionIndexer
Get the maximum dimension value seen by this indexer.
getMaxValue() - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
getMaxValue() - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
getMaxValue(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getMaxValue(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getMaxValue() - Method in class org.apache.druid.segment.LongDimensionIndexer
 
getMaxValue(String) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getMaxValue(String) - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getMaxValue(String) - Method in interface org.apache.druid.segment.StorageAdapter
 
getMaxValue() - Method in class org.apache.druid.segment.StringDimensionIndexer
 
getMaxVectorSize() - Method in class org.apache.druid.query.filter.vector.BaseVectorValueMatcher
 
getMaxVectorSize() - Method in class org.apache.druid.query.filter.vector.FalseVectorMatcher
 
getMaxVectorSize() - Method in class org.apache.druid.query.filter.vector.TrueVectorMatcher
 
getMaxVectorSize() - Method in class org.apache.druid.segment.vector.BaseDoubleVectorValueSelector
 
getMaxVectorSize() - Method in class org.apache.druid.segment.vector.BaseFloatVectorValueSelector
 
getMaxVectorSize() - Method in class org.apache.druid.segment.vector.BaseLongVectorValueSelector
 
getMaxVectorSize() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
getMaxVectorSize() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
getMaxVectorSize() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getMaxVectorSize() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
getMaxVectorSize() - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
Returns the maximum vector size for the VectorCursor that generated this object.
getMaxVectorSize() - Method in interface org.apache.druid.segment.vector.VectorSizeInspector
Returns the maximum vector size for this cursor.
getMaxVectorSize() - Method in class org.apache.druid.segment.virtual.ExpressionVectorObjectSelector
 
getMaxVectorSize() - Method in class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
 
getMean() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getMergeBuffer() - Method in class org.apache.druid.query.groupby.resource.GroupByQueryResource
Get a merge buffer from the pre-acquired resources.
getMergedDimensions(List<IndexableAdapter>) - Static method in interface org.apache.druid.segment.IndexMerger
 
getMergedDimensionsFromQueryableIndexes(List<QueryableIndex>) - Static method in interface org.apache.druid.segment.IndexMerger
 
getMergeFunction() - Method in interface org.apache.druid.query.context.ResponseContext.BaseKey
Merge function associated with a key: Object (Object oldValue, Object newValue)
getMergeFunction() - Method in enum org.apache.druid.query.context.ResponseContext.Key
 
getMergePoolAwaitShutdownMillis() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getMergePoolDefaultMaxQueryParallelism() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getMergePoolParallelism() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getMergePoolParallelismConfigured() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getMergePoolSmallBatchRows() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getMergePoolTargetTaskRunTimeMillis() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getMergePoolTaskInitialYieldRows() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getMergingFactory(AggregatorFactory) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Returns an AggregatorFactory that can be used to combine the output of aggregators from this factory and another factory.
getMergingFactory(AggregatorFactory) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getMergingFactory(AggregatorFactory) - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getMergingFactory(AggregatorFactory) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
getMergingFactory(AggregatorFactory) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
getMergingFactory(AggregatorFactory) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
getMergingFactory(AggregatorFactory) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getMessage() - Method in exception org.apache.druid.query.QueryException
 
getMetadata() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMetadata() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getMetadata() - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getMetadata() - Method in interface org.apache.druid.segment.IndexableAdapter
 
getMetadata() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getMetadata() - Method in interface org.apache.druid.segment.QueryableIndex
 
getMetadata() - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getMetadata() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getMetadata() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getMetadata() - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getMetadata() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getMetadata() - Method in interface org.apache.druid.segment.StorageAdapter
 
getMetric(String) - Method in class org.apache.druid.query.MetricValueExtractor
 
getMetric() - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
getMetric(String) - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
getMetricAggs() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMetricCompression() - Method in class org.apache.druid.segment.IndexSpec
 
getMetricDoubleValue(int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMetricDoubleValue(int, int) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getMetricDoubleValue(int, int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getMetricFloatValue(int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMetricFloatValue(int, int) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getMetricFloatValue(int, int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getMetricHolder(String) - Method in class org.apache.druid.segment.MMappedIndex
 
getMetricLongValue(int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMetricLongValue(int, int) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getMetricLongValue(int, int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getMetricName(DimensionSpec) - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
getMetricName(DimensionSpec) - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
getMetricName(DimensionSpec) - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
getMetricName(DimensionSpec) - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
getMetricName(DimensionSpec) - Method in interface org.apache.druid.query.topn.TopNMetricSpec
 
getMetricNames() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMetricNames() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getMetricNames() - Method in interface org.apache.druid.segment.IndexableAdapter
 
getMetricNames() - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getMetricNames() - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getMetricObjectValue(int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMetricObjectValue(int, int) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getMetricObjectValue(int, int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getMetrics() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
 
getMetricType(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMetricType(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getMetricType(String) - Method in interface org.apache.druid.segment.IndexableAdapter
 
getMetricType(String) - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getMetricType(String) - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getMetricValues() - Method in class org.apache.druid.query.topn.DimValHolder
 
getMinCardinalityToUseBitmapIndex() - Method in class org.apache.druid.query.filter.FilterTuning
 
getMinCoordinates() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getMinCoordinates() - Method in class org.apache.druid.collections.spatial.Node
 
getMinCoords() - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
getMinorVersion() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
getMinTime() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
 
getMinTime() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getMinTime() - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getMinTime() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getMinTime() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getMinTime() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getMinTime() - Method in interface org.apache.druid.segment.StorageAdapter
 
getMinTimestamp() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
 
getMinTopNThreshold() - Method in class org.apache.druid.query.topn.TopNQueryConfig
 
getMinValue() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
getMinValue() - Method in interface org.apache.druid.segment.DimensionIndexer
Get the minimum dimension value seen by this indexer.
getMinValue() - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
getMinValue() - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
getMinValue(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getMinValue(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getMinValue() - Method in class org.apache.druid.segment.LongDimensionIndexer
 
getMinValue(String) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getMinValue(String) - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getMinValue(String) - Method in interface org.apache.druid.segment.StorageAdapter
 
getMinValue() - Method in class org.apache.druid.segment.StringDimensionIndexer
 
getMostSpecificId() - Method in interface org.apache.druid.query.Query
Returns a most specific ID of this query; if it is a subquery, this will return its subquery ID.
getMovingAverages() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
getMovingAverages() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
getMultivalueHandling() - Method in interface org.apache.druid.segment.DimensionHandler
Get DimensionSchema.MultiValueHandling for the column associated with this handler.
getMultivalueHandling() - Method in class org.apache.druid.segment.StringDimensionHandler
 
getMultiValueRow(int) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
getMultiValueRow(int) - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
getName() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
getName() - Method in interface org.apache.druid.query.aggregation.PostAggregator
 
getName() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
getName() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getName() - Method in class org.apache.druid.query.ColumnSelectorPlus
 
getName() - Method in interface org.apache.druid.query.context.ResponseContext.BaseKey
 
getName() - Method in enum org.apache.druid.query.context.ResponseContext.Key
 
getName() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
getName() - Method in class org.apache.druid.query.TableDataSource
 
getName() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getName() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
 
getName() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.MetricDesc
 
getName() - Method in class org.apache.druid.segment.MetricHolder
 
getName() - Method in class org.apache.druid.segment.transform.ExpressionTransform
 
getName() - Method in interface org.apache.druid.segment.transform.Transform
Returns the field name for this transform.
getNonEquiConditions() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
Return a list of non-equi-conditions (see class-level javadoc).
getNormalizedBaseTableClauses() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getNormalizedJoinTableClauses() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getNullHandling() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
getNullProbability() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getNullVector() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getNullVector() - Method in interface org.apache.druid.segment.vector.VectorValueSelector
Gets a vector of booleans signifying which rows are null and which are not (true for null).
getNullVector() - Method in class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
 
getNumBytes(int) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
Get the number of bytes required to encoding the given number of values
getNumBytes(int) - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
getNumBytes(int) - Method in class org.apache.druid.segment.data.LongsLongEncodingWriter
 
getNumBytes(int) - Method in class org.apache.druid.segment.data.TableLongEncodingWriter
 
getNumBytes() - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
getNumBytesForMax(int) - Static method in class org.apache.druid.segment.data.VSizeColumnarInts
 
getNumBytesNoPadding() - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
getNumBytesPerRecord() - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
 
getNumDims() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getNumDims() - Method in class org.apache.druid.collections.spatial.Node
 
getNumDims() - Method in class org.apache.druid.collections.spatial.RTree
 
getNumDims() - Method in interface org.apache.druid.collections.spatial.search.Bound
 
getNumDims() - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
getNumericalMean() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
getNumericalVariance() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
getNumLookupLoadingThreads() - Method in class org.apache.druid.query.lookup.LookupConfig
 
getNumMergeBuffers() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getNumMergeBuffersConfigured() - Method in class org.apache.druid.query.DruidProcessingConfig
Returns the number of merge buffers _explicitly_ configured, or -1 if it is not explicitly configured, that is not a valid number of buffers.
getNumMetrics() - Method in class org.apache.druid.segment.TimeAndDimsPointer
 
getNumParallelCombineThreads() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
getNumReferences() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
 
getNumRetriesOnMissingSegments(Query<T>, int) - Static method in class org.apache.druid.query.QueryContexts
 
getNumRows() - Method in interface org.apache.druid.query.filter.BitmapIndexSelector
 
getNumRows() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
getNumRows() - Method in class org.apache.druid.segment.ColumnSelectorBitmapIndexSelector
 
getNumRows() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getNumRows() - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
getNumRows() - Method in interface org.apache.druid.segment.IndexableAdapter
 
getNumRows() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
getNumRows() - Method in interface org.apache.druid.segment.QueryableIndex
 
getNumRows() - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getNumRows() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
getNumRows() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
getNumRows() - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getNumRows() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
getNumRows() - Method in interface org.apache.druid.segment.StorageAdapter
 
getNumThreadsConfigured() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getNumValuesPerBlock(int, int) - Static method in class org.apache.druid.segment.data.VSizeLongSerde
Block size should be power of 2, so ColumnarLongs.get(int) can be optimized using bit operators.
getNumValuesPerPass() - Method in class org.apache.druid.query.topn.TopNParams
 
getObject() - Method in class org.apache.druid.query.aggregation.cardinality.HyperLogLogCollectorAggregateCombiner
 
getObject() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregateCombiner
 
getObject() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregateCombiner
 
getObject() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
getObject() - Method in class org.apache.druid.segment.AbstractDimensionSelector
 
getObject() - Method in interface org.apache.druid.segment.BaseObjectColumnValueSelector
 
getObject() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
getObject() - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
getObject() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
 
getObject() - Method in interface org.apache.druid.segment.DoubleColumnSelector
Deprecated.
This method is marked as deprecated in DoubleColumnSelector to minimize the probability of accidental calling. "Polymorphism" of DoubleColumnSelector should be used only when operating on ColumnValueSelector objects.
getObject() - Method in interface org.apache.druid.segment.FloatColumnSelector
Deprecated.
This method is marked as deprecated in FloatColumnSelector to minimize the probability of accidental calling. "Polymorphism" of FloatColumnSelector should be used only when operating on ColumnValueSelector objects.
getObject() - Method in class org.apache.druid.segment.join.PossiblyNullColumnValueSelector
 
getObject() - Method in class org.apache.druid.segment.join.table.IndexedTableColumnValueSelector
 
getObject() - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
getObject() - Method in interface org.apache.druid.segment.LongColumnSelector
Deprecated.
This method is marked as deprecated in LongColumnSelector to minimize the probability of accidental calling. "Polymorphism" of LongColumnSelector should be used only when operating on ColumnValueSelector objects.
getObject() - Method in class org.apache.druid.segment.NilColumnValueSelector
Always returns null.
getObject() - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
getObject() - Method in class org.apache.druid.segment.selector.settable.SettableObjectColumnValueSelector
 
getObject() - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
getObject() - Method in class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
 
getObject() - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
getObject() - Method in class org.apache.druid.segment.virtual.RowBasedExpressionColumnValueSelector
 
getObject() - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
 
getObject() - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
 
getObject() - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
getObjectStrategy() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
 
getObjectStrategy() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringSerde
 
getObjectStrategy() - Method in interface org.apache.druid.segment.data.BitmapSerdeFactory
 
getObjectStrategy() - Method in class org.apache.druid.segment.data.ConciseBitmapSerdeFactory
 
getObjectStrategy() - Method in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
 
getObjectStrategy() - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
Deprecated.
getObjectVector() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getObjectVector() - Method in interface org.apache.druid.segment.vector.VectorObjectSelector
Get the current vector.
getObjectVector() - Method in class org.apache.druid.segment.virtual.ExpressionVectorObjectSelector
 
getOffset() - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
getOffset() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
Offset for this query; behaves like SQL "OFFSET".
getOffset() - Method in class org.apache.druid.segment.BitmapOffset
 
getOffset() - Method in interface org.apache.druid.segment.data.ReadableOffset
 
getOffset() - Method in class org.apache.druid.segment.FilteredOffset
 
getOffset() - Method in interface org.apache.druid.segment.historical.HistoricalCursor
 
getOffset() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset
 
getOffset() - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
getOffset() - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
getOffsetForBucket(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
getOffsetFromInitial() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
getOffsets() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
getOffsets() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
getOffsets() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
getOffsets() - Method in interface org.apache.druid.segment.vector.ReadableVectorOffset
If "isContiguous" is false, this method returns a batch of offsets.
getOnlyValue(ColumnValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DictionaryBuildingStringGroupByColumnSelectorStrategy
 
getOnlyValue(ColumnValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
getOnlyValue(ColumnValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
getOnlyValue(ColumnValueSelector) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
Retrieve a single object using the ColumnValueSelector.
getOnlyValue(ColumnValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
getOnlyValue(ColumnValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
getOnlyValue(ColumnValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 
getOrder() - Method in class org.apache.druid.query.scan.ScanQuery
 
getOrderByForDimName(List<OrderByColumnSpec>, String) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
getOrdering() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
getOrdering() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
getOrdering() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getOrdering() - Method in class org.apache.druid.query.search.SearchSortSpec
 
getOrdering() - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
getOrdinate() - Method in class org.apache.druid.collections.spatial.search.PolygonBound
 
getOriginalExpression() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
Return the condition expression.
getOriginalFilter() - Method in class org.apache.druid.segment.join.filter.JoinFilterAnalysis
 
getOriginalFilter() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getOutOfRowsReason() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
getOutOfRowsReason() - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
getOutOfRowsReason() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
getOutputBytes() - Static method in class org.apache.druid.segment.CompressedPools
 
getOutputName() - Method in class org.apache.druid.query.ColumnSelectorPlus
 
getOutputName() - Method in class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
getOutputName() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
getOutputName() - Method in interface org.apache.druid.query.dimension.DimensionSpec
 
getOutputName() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
getOutputName() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
getOutputName() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
getOutputName() - Method in interface org.apache.druid.segment.VirtualColumn
Output name of this column.
getOutputType() - Method in class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
getOutputType() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
getOutputType() - Method in interface org.apache.druid.query.dimension.DimensionSpec
 
getOutputType() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
getOutputType() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
getOutputType(Expr.InputBindingTypes) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorDynamicExpr
 
getOutputType(Expr.InputBindingTypes) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
 
getOutputType() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
getOutputType() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
getParallelMergeInitialYieldRows(Query<T>, int) - Static method in class org.apache.druid.query.QueryContexts
 
getParallelMergeParallelism(Query<T>, int) - Static method in class org.apache.druid.query.QueryContexts
 
getParallelMergeSmallBatchRows(Query<T>, int) - Static method in class org.apache.druid.query.QueryContexts
 
getParent() - Method in class org.apache.druid.collections.spatial.Node
 
getParsedExpression() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
getParseException() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
getParseSpec() - Method in class org.apache.druid.segment.transform.TransformingInputRowParser
 
getParts() - Method in class org.apache.druid.segment.column.ColumnDescriptor
 
getPattern() - Method in class org.apache.druid.query.dimension.RegexFilteredDimensionSpec
 
getPattern() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
getPattern() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
getPattern() - Method in class org.apache.druid.query.search.RegexSearchQuerySpec
 
getPointer() - Method in class org.apache.druid.segment.ForwardingRowIterator
 
getPointer() - Method in interface org.apache.druid.segment.RowIterator
Returns a pointer to the current row.
getPointer() - Method in interface org.apache.druid.segment.TimeAndDimsIterator
Returns a pointer to the current data point.
getPointer() - Method in interface org.apache.druid.segment.TransformableRowIterator
Returns a pointer to the current row.
getPool() - Method in class org.apache.druid.guice.LifecycleForkJoinPoolProvider
 
getPostAggIndexForOrderBy(OrderByColumnSpec, List<PostAggregator>) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
getPostAggregatorSpecs() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getPostAggregatorSpecs() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
getPostAggregatorSpecs() - Method in class org.apache.druid.query.topn.TopNQuery
 
getPostFilter() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter.FilterAnalysis
 
getPostJoinVirtualColumns() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
getPreFilterBitmap() - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter.FilterAnalysis
 
getPrefix() - Method in class org.apache.druid.query.dimension.PrefixFilteredDimensionSpec
 
getPrefix() - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
 
getPrefix() - Method in class org.apache.druid.query.planning.PreJoinableClause
 
getPrefix() - Method in class org.apache.druid.segment.join.JoinableClause
The prefix to apply to all columns from the Joinable.
getPreJoinableClauses() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns join clauses corresponding to joinable leaf datasources (every leaf except the bottom-leftmost).
getPreviousStop() - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
getPreviousStop() - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
getPriority() - Method in class org.apache.druid.query.AbstractPrioritizedCallable
 
getPriority() - Method in interface org.apache.druid.query.PrioritizedCallable
 
getPriority() - Method in interface org.apache.druid.query.PrioritizedRunnable
 
getPriority(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getPriority(Query<T>, int) - Static method in class org.apache.druid.query.QueryContexts
 
getProcessed() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
getProcessed() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
getProcessed() - Method in class org.apache.druid.segment.incremental.RowIngestionMetersTotals
 
getProcessedWithError() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
getProcessedWithError() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
getProcessedWithError() - Method in class org.apache.druid.segment.incremental.RowIngestionMetersTotals
 
getPushDownFilter() - Method in class org.apache.druid.segment.join.filter.JoinFilterAnalysis
 
getPushDownVirtualColumns() - Method in class org.apache.druid.segment.join.filter.JoinFilterSplit
 
getQuery() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
getQuery() - Method in class org.apache.druid.query.QueryDataSource
 
getQuery() - Method in class org.apache.druid.query.QueryPlus
 
getQuery() - Method in class org.apache.druid.query.search.SearchQuery
 
getQueryGranularity() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
getQueryGranularity() - Method in class org.apache.druid.segment.Metadata
 
getQueryMetrics() - Method in class org.apache.druid.query.QueryPlus
 
getQueryRunnerForIntervals(Query<T>, Iterable<Interval>) - Method in interface org.apache.druid.query.QuerySegmentWalker
Gets the Queryable for a given interval, the Queryable returned can be any version(s) or partitionNumber(s) such that it represents the interval.
getQueryRunnerForSegments(Query<T>, Iterable<SegmentDescriptor>) - Method in interface org.apache.druid.query.QuerySegmentWalker
Gets the Queryable for a given list of SegmentDescriptors.
getQuerySegmentSpec() - Method in class org.apache.druid.query.BaseQuery
 
getQuerySegmentSpecForLookUp(BaseQuery<?>) - Static method in class org.apache.druid.query.BaseQuery
 
getQueueSize() - Method in class org.apache.druid.query.PrioritizedExecutorService
 
getRadius() - Method in class org.apache.druid.collections.spatial.search.RadiusBound
 
getRaw(String) - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
getReader(ByteBuffer, ByteOrder) - Method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
 
getReason() - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
 
getReasonOfNotAdded() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
getRegrowthThreshold() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
getReplaceMissingValueWith() - Method in class org.apache.druid.query.extraction.FunctionalExtraction
 
getReplaceMissingValueWith() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
getReplaceMissingValueWith() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
getReplaceMissingValueWith() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Used by GroupByStrategyV1 when running nested groupBys, to "transfer" values from this aggreagtor to an incremental index that the outer query will run on.
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.AndDimFilter
 
getRequiredColumns() - Method in interface org.apache.druid.query.filter.BooleanFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
getRequiredColumns() - Method in interface org.apache.druid.query.filter.DimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.FalseDimFilter
 
getRequiredColumns() - Method in interface org.apache.druid.query.filter.Filter
Set of columns used by a filter.
getRequiredColumns() - Method in class org.apache.druid.query.filter.InDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.NotDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.OrDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.query.filter.TrueDimFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.BoundFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.FalseFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.LikeFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.NotFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.SelectorFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.SpatialFilter
 
getRequiredColumns() - Method in class org.apache.druid.segment.filter.TrueFilter
 
getResult() - Method in class org.apache.druid.query.context.ResponseContext.SerializationResult
Returns the truncated result if it exists otherwise returns the full result.
getResultBuilder(DateTime, DimensionSpec, int, Comparator, List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
getResultBuilder(DateTime, DimensionSpec, int, Comparator, List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
getResultBuilder(DateTime, DimensionSpec, int, Comparator, List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
getResultBuilder(DateTime, DimensionSpec, int, Comparator, List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
getResultBuilder(DateTime, DimensionSpec, int, Comparator, List<AggregatorFactory>, List<PostAggregator>) - Method in interface org.apache.druid.query.topn.TopNMetricSpec
 
getResultFormat() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
getResultFormat() - Method in class org.apache.druid.query.scan.ScanQuery
 
getResultOrdering() - Method in class org.apache.druid.query.BaseQuery
Default implementation of Query.getResultOrdering() that uses Ordering.natural().
getResultOrdering() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getResultOrdering() - Method in interface org.apache.druid.query.Query
Comparator that represents the order in which results are generated from the QueryRunnerFactory.createRunner(Segment) and QueryRunnerFactory.mergeRunners(ExecutorService, Iterable) calls.
getResultOrdering() - Method in class org.apache.druid.query.scan.ScanQuery
 
getResultOrdering() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getResultRowAggregatorStart() - Method in class org.apache.druid.query.groupby.GroupByQuery
Returns the position of the first aggregator in ResultRows for this query.
getResultRowDimensionStart() - Method in class org.apache.druid.query.groupby.GroupByQuery
Returns the position of the first dimension in ResultRows for this query.
getResultRowHasTimestamp() - Method in class org.apache.druid.query.groupby.GroupByQuery
Returns true if ResultRows for this query include timestamps, false otherwise.
getResultRowPosition() - Method in class org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorPlus
 
getResultRowPostAggregatorStart() - Method in class org.apache.druid.query.groupby.GroupByQuery
Returns the position of the first post-aggregator in ResultRows for this query.
getResultRowSignature() - Method in class org.apache.druid.query.groupby.GroupByQuery
Returns a list of field names, of the same size as GroupByQuery.getResultRowSizeWithPostAggregators(), in the order that they will appear in ResultRows for this query.
getResultRowSizeWithoutPostAggregators() - Method in class org.apache.druid.query.groupby.GroupByQuery
Returns the size of ResultRows for this query when they do not include post-aggregators.
getResultRowSizeWithPostAggregators() - Method in class org.apache.druid.query.groupby.GroupByQuery
Returns the size of ResultRows for this query when they include post-aggregators.
getResults() - Method in interface org.apache.druid.query.BySegmentResultValue
 
getResults() - Method in class org.apache.druid.query.BySegmentResultValueClass
 
getResults() - Method in class org.apache.druid.query.search.BySegmentSearchResultValue
 
getResults() - Method in class org.apache.druid.query.topn.BySegmentTopNResultValue
 
getResultsBuf() - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
 
getResultsBufHolder() - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
 
getResultTypeReference() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
 
getResultTypeReference() - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
getResultTypeReference() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
getResultTypeReference() - Method in class org.apache.druid.query.QueryToolChest
Returns a TypeReference object that is just passed through to Jackson in order to deserialize the results of this type of query.
getResultTypeReference() - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
 
getResultTypeReference() - Method in class org.apache.druid.query.search.SearchQueryQueryToolChest
 
getResultTypeReference() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
getResultTypeReference() - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
getResultTypeReference() - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
getRewriteConfig() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysisKey
 
getRhsColumn() - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidate
 
getRhsRewriteCandidates() - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidates
 
getRhsRewriteCandidates(List<Filter>, Equiconditions, JoinableClauses) - Static method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidates
Determine candidates for filter rewrites.
getRight() - Method in class org.apache.druid.query.JoinDataSource
 
getRightColumn() - Method in class org.apache.druid.segment.join.Equality
 
getRightEquiConditionKeys() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
Returns the distinct column keys from the RHS required to evaluate the equi conditions.
getRightPrefix() - Method in class org.apache.druid.query.JoinDataSource
 
getRoot() - Method in class org.apache.druid.collections.spatial.RTree
 
getRow() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
getRow() - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
getRow(int) - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
getRow() - Method in interface org.apache.druid.segment.DimensionSelector
Returns the indexed values at the current position in this DimensionSelector.
getRow(int) - Method in interface org.apache.druid.segment.historical.HistoricalDimensionSelector
 
getRow() - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
getRow() - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
getRow() - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
getRow() - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
getRow() - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
getRow() - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
Get the underlying selector IndexedInts row
getRowCount() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
getRowFunction() - Method in class org.apache.druid.segment.transform.ExpressionTransform
 
getRowFunction() - Method in interface org.apache.druid.segment.transform.Transform
Returns the function for this transform.
getRowIndex() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
 
getRowNum() - Method in class org.apache.druid.segment.RowPointer
 
getRowOrdering(boolean) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getRows() - Method in class org.apache.druid.query.InlineDataSource
Returns rows as an Iterable.
getRows() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
getRows() - Method in interface org.apache.druid.segment.IndexableAdapter
 
getRows() - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
getRows() - Method in class org.apache.druid.segment.RowFilteringIndexAdapter
 
getRowsAsList() - Method in class org.apache.druid.query.InlineDataSource
Returns rows as a list.
getRowSelector(TopNQuery, TopNParams, StorageAdapter) - Method in class org.apache.druid.query.topn.types.NullableNumericTopNColumnAggregatesProcessor
 
getRowSelector(TopNQuery, TopNParams, StorageAdapter) - Method in class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
 
getRowSelector(TopNQuery, TopNParams, StorageAdapter) - Method in interface org.apache.druid.query.topn.types.TopNColumnAggregatesProcessor
getRowSignature() - Method in class org.apache.druid.query.InlineDataSource
Returns the row signature (map of column name to type) for this inline datasource.
getRowSize() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getRowValue(int) - Method in interface org.apache.druid.segment.column.ComplexColumn
Return rows in the column.
getRowValue(int) - Method in class org.apache.druid.segment.column.GenericIndexedBasedComplexColumn
 
getRowValue(int) - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
getRowValue(int) - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
getRowValue(int) - Method in interface org.apache.druid.segment.historical.SingleValueHistoricalDimensionSelector
 
getRowVector() - Method in interface org.apache.druid.segment.vector.MultiValueDimensionVectorSelector
Get the current vector.
getRowVector() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getRowVector() - Method in interface org.apache.druid.segment.vector.SingleValueDimensionVectorSelector
Get the current vector.
getRTree() - Method in interface org.apache.druid.segment.column.SpatialIndex
 
getRunner(QuerySegmentWalker) - Method in class org.apache.druid.query.BaseQuery
 
getRunner(QuerySegmentWalker) - Method in interface org.apache.druid.query.Query
 
getRunner(QuerySegmentWalker) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getSavedParseExceptions() - Method in class org.apache.druid.segment.incremental.ParseExceptionHandler
 
getScanRowsLimit() - Method in class org.apache.druid.query.scan.ScanQuery
Limit for this query; behaves like SQL "LIMIT".
getScanRowsOffset() - Method in class org.apache.druid.query.scan.ScanQuery
Offset for this query; behaves like SQL "OFFSET".
getSchema() - Method in class org.apache.druid.segment.generator.ColumnValueGenerator
 
getSearchQuerySpec() - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
getSearchStrategy() - Method in class org.apache.druid.query.search.SearchQueryConfig
 
getSegmentDescriptor() - Method in class org.apache.druid.query.PerSegmentQueryOptimizationContext
 
getSegmentId() - Method in interface org.apache.druid.query.BySegmentResultValue
 
getSegmentId() - Method in class org.apache.druid.query.BySegmentResultValueClass
 
getSegmentId() - Method in class org.apache.druid.query.scan.ScanResultValue
 
getSegmentId() - Method in class org.apache.druid.query.search.BySegmentSearchResultValue
 
getSegmentId() - Method in class org.apache.druid.query.topn.BySegmentTopNResultValue
 
getSegmentLoader() - Method in class org.apache.druid.segment.IndexSpec
 
getSegmentsForIntervals(DataSource, Iterable<Interval>) - Method in interface org.apache.druid.segment.SegmentWrangler
Gets Segments for a particular datasource and set of intervals.
getSelection() - Method in interface org.apache.druid.query.filter.vector.ReadableVectorMatch
Returns an array of indexes into the current batch.
getSelection() - Method in class org.apache.druid.query.filter.vector.VectorMatch
 
getSelectionSize() - Method in interface org.apache.druid.query.filter.vector.ReadableVectorMatch
Returns the number of valid values in the array from "getSelection".
getSelectionSize() - Method in class org.apache.druid.query.filter.vector.VectorMatch
 
getSelector() - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
getSelector() - Method in class org.apache.druid.query.ColumnSelectorPlus
 
getSelectorPlus() - Method in class org.apache.druid.query.topn.TopNParams
 
getSerdeForType(String) - Static method in class org.apache.druid.segment.serde.ComplexMetrics
 
getSerializedSize() - Method in class org.apache.druid.segment.column.ColumnDescriptor
 
getSerializedSize() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarDoublesSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarFloatsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarLongsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.ByteBufferWriter
 
getSerializedSize() - Method in class org.apache.druid.segment.data.CompressedColumnarFloatsSupplier
 
getSerializedSize() - Method in class org.apache.druid.segment.data.CompressedColumnarIntsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
 
getSerializedSize() - Method in class org.apache.druid.segment.data.CompressedColumnarLongsSupplier
 
getSerializedSize() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
getSerializedSize() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier
 
getSerializedSize() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarFloatsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarLongsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.GenericIndexed
 
getSerializedSize() - Method in class org.apache.druid.segment.data.GenericIndexedWriter
 
getSerializedSize() - Method in class org.apache.druid.segment.data.IntermediateColumnarLongsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
 
getSerializedSize() - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
getSerializedSize() - Method in class org.apache.druid.segment.data.VSizeColumnarIntsSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
getSerializedSize() - Method in class org.apache.druid.segment.data.VSizeColumnarMultiIntsSerializer
 
getSerializedSize(int, int) - Static method in class org.apache.druid.segment.data.VSizeLongSerde
 
getSerializedSize() - Method in class org.apache.druid.segment.DoubleColumnSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.DoubleColumnSerializerV2
 
getSerializedSize() - Method in class org.apache.druid.segment.FloatColumnSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.FloatColumnSerializerV2
 
getSerializedSize() - Method in class org.apache.druid.segment.LongColumnSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.LongColumnSerializerV2
 
getSerializedSize() - Method in class org.apache.druid.segment.serde.ComplexColumnSerializer
 
getSerializedSize() - Method in class org.apache.druid.segment.serde.LargeColumnSupportedComplexColumnSerializer
 
getSerializedSize() - Method in interface org.apache.druid.segment.serde.Serializer
Returns the number of bytes, that this Serializer will write to the output _channel_ (not smoosher) on a Serializer.writeTo(java.nio.channels.WritableByteChannel, org.apache.druid.java.util.common.io.smoosh.FileSmoosher) call.
getSerializer(SegmentWriteOutMedium, String) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
 
getSerializer(SegmentWriteOutMedium, String) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringSerde
 
getSerializer(int, OutputStream) - Static method in class org.apache.druid.segment.data.VSizeLongSerde
 
getSerializer(int, ByteBuffer, int) - Static method in class org.apache.druid.segment.data.VSizeLongSerde
 
getSerializer() - Method in interface org.apache.druid.segment.serde.ColumnPartSerde
 
getSerializer() - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde
 
getSerializer(SegmentWriteOutMedium, String) - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
This method provides the ability for a ComplexMetricSerde to control its own serialization.
getSerializer() - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
 
getSerializer() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde
 
getSerializer() - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2
 
getSerializer() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde
 
getSerializer() - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2
 
getSerializer() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde
 
getSerializer() - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2
 
getSingleInputName() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
getSingleInputType() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
getSingleValueRow(int) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
getSingleValueRow(int) - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
getSize() - Method in class org.apache.druid.collections.spatial.RTree
 
getSize() - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
getSize() - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
getSize() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
getSize() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
getSize() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
getSizeInBytes() - Method in interface org.apache.druid.collections.bitmap.MutableBitmap
Return the size in bytes for the purpose of serialization to a ByteBuffer.
getSizeInBytes() - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
getSizeInBytes() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
getSizeInBytes() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
getSizeInBytes() - Method in class org.apache.druid.collections.spatial.Node
 
getSlice(ByteBuffer, int, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.Groupers
 
getSnapshotColumnCapabilities(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
Sad workaround for SegmentAnalyzer to deal with the fact that the response from IncrementalIndexStorageAdapter.getColumnCapabilities(java.lang.String) is not accurate for string columns, in that it reports all string string columns as having multiple values.
getSnapshotWorkingDir() - Method in class org.apache.druid.query.lookup.LookupConfig
 
getSort() - Method in class org.apache.druid.query.search.SearchQuery
 
getSortedEncodedValueFromUnsorted(Integer) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
getSortedIndexedValues() - Method in interface org.apache.druid.segment.DimensionIndexer
Returns an indexed structure of this dimension's sorted actual values.
getSortedIndexedValues() - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
getSortedIndexedValues() - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
getSortedIndexedValues() - Method in class org.apache.druid.segment.LongDimensionIndexer
 
getSortedIndexedValues() - Method in class org.apache.druid.segment.StringDimensionIndexer
 
getSpatialIndex(String) - Method in interface org.apache.druid.query.filter.BitmapIndexSelector
 
getSpatialIndex() - Method in interface org.apache.druid.segment.column.ColumnHolder
 
getSpatialIndex(String) - Method in class org.apache.druid.segment.ColumnSelectorBitmapIndexSelector
 
getSpatialIndexes() - Method in class org.apache.druid.segment.MMappedIndex
 
getSpecializationState(Class<? extends T>, String) - Static method in class org.apache.druid.query.monomorphicprocessing.SpecializationService
 
getSpecializationState(Class<? extends T>, String, ImmutableMap<Class<?>, Class<?>>) - Static method in class org.apache.druid.query.monomorphicprocessing.SpecializationService
 
getSpecialized() - Method in class org.apache.druid.query.monomorphicprocessing.SpecializationState
Returns an instance of specialized version of query processing algorithm, if available, null otherwise.
getSpecializedOrDefault(T) - Method in class org.apache.druid.query.monomorphicprocessing.SpecializationState
Returns an instance of specialized version of query processing algorithm, if available, defaultInstance otherwise.
getSqlQueryId() - Method in class org.apache.druid.query.BaseQuery
 
getSqlQueryId() - Method in interface org.apache.druid.query.Query
 
getStandardDeviation() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getStartDouble() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getStartInt() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getStartOffset() - Method in class org.apache.druid.query.vector.VectorCursorGranularizer
 
getStartOffset() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
getStartOffset() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
getStartOffset() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
getStartOffset() - Method in interface org.apache.druid.segment.vector.ReadableVectorOffset
If "isContiguous" is true, this method returns the start offset of the range.
getStartRootPartitionId() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
getStrategySelector() - Method in class org.apache.druid.query.groupby.GroupByQueryRunnerFactory
 
getSubQueryId() - Method in class org.apache.druid.query.BaseQuery
 
getSubQueryId() - Method in interface org.apache.druid.query.Query
Returns the subQueryId of this query.
getSubQueryId() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getSubtotalsSpec() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getSuffixMatch() - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
 
getSupportLowerBound() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
getSupportUpperBound() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
getTableBuffer() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
getTableNames() - Method in interface org.apache.druid.query.DataSource
Returns the names of all table datasources involved in this query.
getTableNames() - Method in class org.apache.druid.query.InlineDataSource
 
getTableNames() - Method in class org.apache.druid.query.JoinDataSource
 
getTableNames() - Method in class org.apache.druid.query.LookupDataSource
 
getTableNames() - Method in class org.apache.druid.query.QueryDataSource
 
getTableNames() - Method in class org.apache.druid.query.TableDataSource
 
getTableNames() - Method in class org.apache.druid.query.UnionDataSource
 
getThreshold() - Method in class org.apache.druid.query.topn.TopNQuery
 
getThrownAway() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
getThrownAway() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
getThrownAway() - Method in class org.apache.druid.segment.incremental.RowIngestionMetersTotals
 
getTime() - Method in interface org.apache.druid.segment.Cursor
 
getTime() - Method in class org.apache.druid.segment.join.PostJoinCursor
 
getTime() - Method in class org.apache.druid.segment.RowBasedCursor
 
getTimeFormat() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
getTimeout(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getTimeout(Query<T>, long) - Static method in class org.apache.druid.query.QueryContexts
 
getTimestamp() - Method in class org.apache.druid.query.Result
 
getTimestamp() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
 
getTimestamp() - Method in class org.apache.druid.segment.TimeAndDimsPointer
 
getTimestamp() - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
getTimestampFromEpoch() - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
getTimestampResultField() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
getTimestampSpec() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
getTimestampSpec() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
 
getTimestampSpec() - Method in class org.apache.druid.segment.Metadata
 
getTimezone() - Method in class org.apache.druid.query.BaseQuery
 
getTimeZone() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
getTimezone() - Method in interface org.apache.druid.query.Query
 
getTimezone() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getTmpDir() - Method in class org.apache.druid.query.DruidProcessingConfig
 
getToDrop() - Method in class org.apache.druid.query.lookup.LookupsState
 
getToInclude() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
getToLoad() - Method in class org.apache.druid.query.lookup.LookupsState
 
getToolchest() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQueryRunnerFactory
 
getToolchest() - Method in class org.apache.druid.query.groupby.GroupByQueryRunnerFactory
 
getToolChest(QueryType) - Method in class org.apache.druid.query.MapQueryToolChestWarehouse
 
getToolchest() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryRunnerFactory
 
getToolchest() - Method in interface org.apache.druid.query.QueryRunnerFactory
Provides access to the QueryToolChest for this specific Query type.
getToolChest(QueryType) - Method in interface org.apache.druid.query.QueryToolChestWarehouse
 
getToolChest(QueryType) - Method in class org.apache.druid.query.ReflectionQueryToolChestWarehouse
Deprecated.
 
getToolchest() - Method in class org.apache.druid.query.scan.ScanQueryRunnerFactory
 
getToolchest() - Method in class org.apache.druid.query.search.SearchQueryRunnerFactory
 
getToolchest() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryRunnerFactory
 
getToolchest() - Method in class org.apache.druid.query.timeseries.TimeseriesQueryRunnerFactory
 
getToolchest() - Method in class org.apache.druid.query.topn.TopNQueryRunnerFactory
 
getTopNIterator() - Method in class org.apache.druid.query.topn.TopNLexicographicResultBuilder
 
getTopNIterator() - Method in class org.apache.druid.query.topn.TopNNumericResultBuilder
 
getTopNIterator() - Method in interface org.apache.druid.query.topn.TopNResultBuilder
 
getTopNMetricSpec() - Method in class org.apache.druid.query.topn.TopNQuery
 
getTopNMetricVal() - Method in class org.apache.druid.query.topn.DimValHolder
 
getTotals() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
getTotals() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
getTransforms() - Method in class org.apache.druid.segment.transform.TransformSpec
 
getTransformSpec() - Method in class org.apache.druid.segment.transform.TransformingInputRowParser
 
getTransformSpec() - Method in class org.apache.druid.segment.transform.TransformingStringInputRowParser
 
getType() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Get the "intermediate" ValueType for this aggregator.
getType() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
actual type is HyperLogLogCollector
getType() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
getType() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
actual type is Histogram
getType() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
actual type is HyperLogLogCollector
getType() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
getType() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
actual type is DoubleMeanHolder
getType() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
getType() - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
getType() - Method in interface org.apache.druid.query.aggregation.PostAggregator
Return the output type of a row processed with this post aggregator.
getType() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
getType() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
getType() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
getType() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getType() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
getType() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
getType() - Method in interface org.apache.druid.query.Query
 
getType() - Method in class org.apache.druid.query.scan.ScanQuery
 
getType() - Method in class org.apache.druid.query.search.SearchQuery
 
getType() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
getType() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
getType() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
getType() - Method in class org.apache.druid.query.topn.TopNQuery
 
getType() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
Column type, good to know so caller can know what to expect and which optimal selector to use
getType() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
getType(String) - Method in interface org.apache.druid.segment.ColumnInspector
 
getType() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
getType() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.MetricDesc
 
getType() - Method in class org.apache.druid.segment.MetricHolder
 
getTypeName() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
 
getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringSerde
 
getTypeName() - Method in interface org.apache.druid.segment.column.ComplexColumn
 
getTypeName() - Method in class org.apache.druid.segment.column.GenericIndexedBasedComplexColumn
 
getTypeName() - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
getTypeName() - Method in class org.apache.druid.segment.MetricHolder
 
getTypeName() - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde
 
getTypeName() - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
 
getUncoveredIntervalsLimit(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getUncoveredIntervalsLimit(Query<T>, int) - Static method in class org.apache.druid.query.QueryContexts
 
getUniversalTimestamp() - Method in class org.apache.druid.query.groupby.GroupByQuery
If this query has a single universal timestamp, return it.
getUnknownInputs() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
getUnparseable() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
getUnparseable() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
getUnparseable() - Method in class org.apache.druid.segment.incremental.RowIngestionMetersTotals
 
getUnshared(int) - Method in interface org.apache.druid.segment.data.ColumnarMultiInts
Returns the values at a given row index.
getUnshared(int) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
 
getUnshared(int) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
getUnsortedEncodedKeyComponentHashCode(EncodedKeyComponentType) - Method in interface org.apache.druid.segment.DimensionIndexer
Given a row value array from a Row key, generate a hashcode.
getUnsortedEncodedKeyComponentHashCode(Double) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
getUnsortedEncodedKeyComponentHashCode(Float) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
getUnsortedEncodedKeyComponentHashCode(Long) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
getUnsortedEncodedKeyComponentHashCode(int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
getUnsortedEncodedValueFromSorted(EncodedType) - Method in interface org.apache.druid.segment.DimensionIndexer
Given an encoded value that was ordered by associated actual value, return the equivalent encoded value ordered by time of ingestion.
getUnsortedEncodedValueFromSorted(Double) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
getUnsortedEncodedValueFromSorted(Float) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
getUnsortedEncodedValueFromSorted(Long) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
getUnsortedEncodedValueFromSorted(Integer) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
getUpper() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
getUseBitmapIndex() - Method in class org.apache.druid.query.filter.FilterTuning
 
getValue() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
getValue() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
getValue() - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
getValue() - Method in class org.apache.druid.query.groupby.having.EqualToHavingSpec
 
getValue() - Method in class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
 
getValue() - Method in class org.apache.druid.query.groupby.having.LessThanHavingSpec
 
getValue() - Method in class org.apache.druid.query.Result
 
getValue() - Method in class org.apache.druid.query.search.BySegmentSearchResultValue
 
getValue() - Method in class org.apache.druid.query.search.ContainsSearchQuerySpec
 
getValue() - Method in class org.apache.druid.query.search.SearchHit
 
getValue() - Method in class org.apache.druid.query.search.SearchResultValue
 
getValue() - Method in class org.apache.druid.query.topn.BySegmentTopNResultValue
 
getValue() - Method in class org.apache.druid.query.topn.TopNResultValue
 
getValue() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
getValue(int) - Method in interface org.apache.druid.segment.column.BitmapIndex
 
getValue() - Method in class org.apache.druid.segment.DoubleWrappingDimensionSelector
 
getValue() - Method in class org.apache.druid.segment.filter.SelectorFilter
 
getValue() - Method in class org.apache.druid.segment.FloatWrappingDimensionSelector
 
getValue() - Method in class org.apache.druid.segment.LongWrappingDimensionSelector
 
getValueCardinality() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
getValueCardinality() - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
getValueCardinality() - Method in interface org.apache.druid.segment.DimensionDictionarySelector
Value cardinality is the cardinality of the different occurring values.
getValueCardinality() - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
getValueCardinality() - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
getValueCardinality() - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
getValueCardinality() - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
getValueCardinality() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
getValueCardinality() - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
getValueCardinality() - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
getValueForRewrite() - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidate
 
getValues() - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
getValues() - Method in class org.apache.druid.query.filter.InDimFilter
 
getValues() - Method in class org.apache.druid.query.groupby.epinephelinae.Grouper.Entry
 
getValues() - Method in class org.apache.druid.query.search.FragmentSearchQuerySpec
 
getValueType() - Method in class org.apache.druid.segment.column.ColumnDescriptor
 
getValueTypesFromDimensionSpecs(List<DimensionSpec>) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
getVectorize(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getVectorize(Query<T>, QueryContexts.Vectorize) - Static method in class org.apache.druid.query.QueryContexts
 
getVectorizeVirtualColumns(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getVectorizeVirtualColumns(Query<T>, QueryContexts.Vectorize) - Static method in class org.apache.druid.query.QueryContexts
 
getVectorSize(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
getVectorSize(Query<T>, int) - Static method in class org.apache.druid.query.QueryContexts
 
getVectorSizeInspector() - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
 
getVectorSizeInspector() - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
Returns a VectorSizeInspector for the VectorCursor that generated this object.
getVersion() - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
 
getVersion() - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
getVirtualColumn(String) - Method in class org.apache.druid.segment.VirtualColumns
 
getVirtualColumns() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
getVirtualColumns() - Method in interface org.apache.druid.query.Query
 
getVirtualColumns() - Method in class org.apache.druid.query.scan.ScanQuery
 
getVirtualColumns() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
getVirtualColumns() - Method in class org.apache.druid.query.topn.TopNQuery
 
getVirtualColumns() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
 
getVirtualColumns() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysisKey
 
getVirtualColumns() - Method in class org.apache.druid.segment.VirtualColumns
 
getZipfExponent() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
GlobalTableDataSource - Class in org.apache.druid.query
TableDataSource variant for globally available 'broadcast' segments.
GlobalTableDataSource(String) - Constructor for class org.apache.druid.query.GlobalTableDataSource
 
granularity(Granularity) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
granularity(String) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
granularity(Granularity) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
granularity(GroupByQuery) - Method in class org.apache.druid.query.groupby.DefaultGroupByQueryMetrics
 
granularity(GroupByQuery) - Method in interface org.apache.druid.query.groupby.GroupByQueryMetrics
Sets the granularity of BaseQuery.getGranularity() of the given query as dimension.
granularity(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
granularity(SearchQuery) - Method in interface org.apache.druid.query.search.SearchQueryMetrics
Sets the granularity of BaseQuery.getGranularity() of the given query as dimension.
granularity(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetrics
 
granularity(TimeseriesQuery) - Method in interface org.apache.druid.query.timeseries.TimeseriesQueryMetrics
Sets the granularity of BaseQuery.getGranularity() of the given query as dimension.
granularity(TopNQuery) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
granularity(Granularity) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
granularity(TopNQuery) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
Sets the granularity of BaseQuery.getGranularity() of the given query as dimension.
GranularityModule - Class in org.apache.druid.jackson
 
GranularityModule() - Constructor for class org.apache.druid.jackson.GranularityModule
 
GranularityModule.GranularityMixin - Interface in org.apache.druid.jackson
 
GreaterThanHavingSpec - Class in org.apache.druid.query.groupby.having
The ">" operator in a "having" clause.
GreaterThanHavingSpec(String, Number) - Constructor for class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
 
GROUP_BY - Static variable in interface org.apache.druid.query.Query
 
GROUP_BY_MERGE_KEY - Static variable in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
GROUP_BY_MISSING_VALUE - Static variable in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
 
GroupByBinaryFnV2 - Class in org.apache.druid.query.groupby.epinephelinae
Class that knows how to merge aggregator data from two groupBy ResultRow objects that have the same time and dimensions.
GroupByBinaryFnV2(GroupByQuery) - Constructor for class org.apache.druid.query.groupby.epinephelinae.GroupByBinaryFnV2
 
GroupByColumnSelectorPlus - Class in org.apache.druid.query.groupby.epinephelinae.column
 
GroupByColumnSelectorPlus(ColumnSelectorPlus<GroupByColumnSelectorStrategy>, int, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorPlus
 
GroupByColumnSelectorStrategy - Interface in org.apache.druid.query.groupby.epinephelinae.column
Contains a collection of query processing methods for type-specific operations used exclusively by GroupByQueryEngineV2.
GroupByMergedQueryRunner<T> - Class in org.apache.druid.query
 
GroupByMergedQueryRunner(ExecutorService, Supplier<GroupByQueryConfig>, QueryWatcher, NonBlockingPool<ByteBuffer>, Iterable<QueryRunner<T>>) - Constructor for class org.apache.druid.query.GroupByMergedQueryRunner
 
GroupByMergingQueryRunnerV2 - Class in org.apache.druid.query.groupby.epinephelinae
Class that knows how to merge a collection of groupBy QueryRunner objects, called queryables, using a buffer provided by mergeBufferPool and a parallel executor provided by exec.
GroupByMergingQueryRunnerV2(GroupByQueryConfig, ExecutorService, QueryWatcher, Iterable<QueryRunner<ResultRow>>, int, BlockingPool<ByteBuffer>, int, ObjectMapper, String) - Constructor for class org.apache.druid.query.groupby.epinephelinae.GroupByMergingQueryRunnerV2
 
GroupByQuery - Class in org.apache.druid.query.groupby
 
GroupByQuery(DataSource, QuerySegmentSpec, VirtualColumns, DimFilter, Granularity, List<DimensionSpec>, List<AggregatorFactory>, List<PostAggregator>, HavingSpec, LimitSpec, List<List<String>>, Map<String, Object>) - Constructor for class org.apache.druid.query.groupby.GroupByQuery
 
GroupByQuery.Builder - Class in org.apache.druid.query.groupby
 
GroupByQueryConfig - Class in org.apache.druid.query.groupby
 
GroupByQueryConfig() - Constructor for class org.apache.druid.query.groupby.GroupByQueryConfig
 
GroupByQueryEngine - Class in org.apache.druid.query.groupby
 
GroupByQueryEngine(Supplier<GroupByQueryConfig>, NonBlockingPool<ByteBuffer>) - Constructor for class org.apache.druid.query.groupby.GroupByQueryEngine
 
GroupByQueryEngineV2 - Class in org.apache.druid.query.groupby.epinephelinae
Class that knows how to process a groupBy query on a single StorageAdapter.
GroupByQueryHelper - Class in org.apache.druid.query.groupby
 
GroupByQueryHelper() - Constructor for class org.apache.druid.query.groupby.GroupByQueryHelper
 
GroupByQueryMetrics - Interface in org.apache.druid.query.groupby
Specialization of QueryMetrics for GroupByQuery.
GroupByQueryMetricsFactory - Interface in org.apache.druid.query.groupby
Implementations could be injected using PolyBind .optionBinder(binder, Key.get(GroupByQueryMetricsFactory.class)) .addBinding("myCustomGroupByQueryMetricsFactory") .to(MyCustomGroupByQueryMetricsFactory.class); And then setting property: druid.query.groupBy.queryMetricsFactory=myCustomGroupByQueryMetricsFactory
GroupByQueryQueryToolChest - Class in org.apache.druid.query.groupby
 
GroupByQueryQueryToolChest(GroupByStrategySelector) - Constructor for class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
GroupByQueryQueryToolChest(GroupByStrategySelector, GroupByQueryMetricsFactory) - Constructor for class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
GroupByQueryResource - Class in org.apache.druid.query.groupby.resource
This class contains resources required for a groupBy query execution.
GroupByQueryResource() - Constructor for class org.apache.druid.query.groupby.resource.GroupByQueryResource
 
GroupByQueryResource(List<ReferenceCountingResourceHolder<ByteBuffer>>) - Constructor for class org.apache.druid.query.groupby.resource.GroupByQueryResource
 
GroupByQueryRunnerFactory - Class in org.apache.druid.query.groupby
 
GroupByQueryRunnerFactory(GroupByStrategySelector, GroupByQueryQueryToolChest) - Constructor for class org.apache.druid.query.groupby.GroupByQueryRunnerFactory
 
GroupByRowProcessor - Class in org.apache.druid.query.groupby.epinephelinae
Utility class that knows how to do higher-level groupBys: i.e.
GroupByRowProcessor.ResultSupplier - Interface in org.apache.druid.query.groupby.epinephelinae
 
GroupByStrategy - Interface in org.apache.druid.query.groupby.strategy
 
GroupByStrategySelector - Class in org.apache.druid.query.groupby.strategy
 
GroupByStrategySelector(Supplier<GroupByQueryConfig>, GroupByStrategyV1, GroupByStrategyV2) - Constructor for class org.apache.druid.query.groupby.strategy.GroupByStrategySelector
 
GroupByStrategyV1 - Class in org.apache.druid.query.groupby.strategy
 
GroupByStrategyV1(Supplier<GroupByQueryConfig>, GroupByQueryEngine, QueryWatcher, NonBlockingPool<ByteBuffer>) - Constructor for class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
GroupByStrategyV2 - Class in org.apache.druid.query.groupby.strategy
 
GroupByStrategyV2(DruidProcessingConfig, Supplier<GroupByQueryConfig>, NonBlockingPool<ByteBuffer>, BlockingPool<ByteBuffer>, ObjectMapper, QueryWatcher) - Constructor for class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
GroupByVectorColumnProcessorFactory - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
GroupByVectorColumnSelector - Interface in org.apache.druid.query.groupby.epinephelinae.vector
Column processor for groupBy dimensions.
Grouper<KeyType> - Interface in org.apache.druid.query.groupby.epinephelinae
Groupers aggregate metrics from rows that they typically get from a ColumnSelectorFactory, under grouping keys that some outside driver is passing in.
Grouper.BufferComparator - Interface in org.apache.druid.query.groupby.epinephelinae
 
Grouper.Entry<T> - Class in org.apache.druid.query.groupby.epinephelinae
 
Grouper.KeySerde<T> - Interface in org.apache.druid.query.groupby.epinephelinae
Possibly-stateful object responsible for serde and comparison of keys.
Grouper.KeySerdeFactory<T> - Interface in org.apache.druid.query.groupby.epinephelinae
 
GrouperBufferComparatorUtils - Class in org.apache.druid.query.groupby.epinephelinae
GrouperBufferComparatorUtils() - Constructor for class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
 
Groupers - Class in org.apache.druid.query.groupby.epinephelinae
 
growthCount - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
GuiceExprMacroTable - Class in org.apache.druid.query.expression
 
GuiceExprMacroTable(Set<ExprMacroTable.ExprMacro>) - Constructor for class org.apache.druid.query.expression.GuiceExprMacroTable
 
GuiceInjectors - Class in org.apache.druid.guice
 
GuiceInjectors() - Constructor for class org.apache.druid.guice.GuiceInjectors
 
GutmanSearchStrategy - Class in org.apache.druid.collections.spatial.search
 
GutmanSearchStrategy() - Constructor for class org.apache.druid.collections.spatial.search.GutmanSearchStrategy
 
GutmanSplitStrategy - Class in org.apache.druid.collections.spatial.split
 
GutmanSplitStrategy(int, int, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.split.GutmanSplitStrategy
 

H

handle(ParseException) - Method in class org.apache.druid.segment.incremental.ParseExceptionHandler
 
handleBucketMove(int, int, ByteBuffer, ByteBuffer) - Method in interface org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable.BucketUpdateHandler
 
handleNewBucket(int) - Method in interface org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable.BucketUpdateHandler
 
handlePreTableSwap() - Method in interface org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable.BucketUpdateHandler
 
hasAggregators() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
hasBitmapIndexes() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
Does the column have an inverted index bitmap for each value? If so, these may be employed to 'pre-filter' the column by examining if the values match the filter and intersecting the bitmaps, to avoid having to scan and evaluate if every row matches the filter
hasBitmapIndexes() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
hasEncodingFlag(byte) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
hasFilters() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
hasFilters(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
hasFilters() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
hasFilters() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
hasFilters() - Method in interface org.apache.druid.query.Query
 
hasFilters(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.hasFilters() of the given query as dimension.
hasFilters() - Method in class org.apache.druid.query.scan.ScanQuery
 
hasFilters(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
hasFilters() - Method in class org.apache.druid.query.search.SearchQuery
 
hasFilters() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
hasFilters() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
hasFilters() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
hasFilters() - Method in class org.apache.druid.query.topn.TopNQuery
 
HASH_FUNCTION - Static variable in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
 
HASH_SIZE - Static variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
HASH_SIZE - Static variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
hashCode() - Method in class org.apache.druid.collections.spatial.ImmutableRTree
 
hashCode() - Method in class org.apache.druid.collections.spatial.search.PolygonBound
 
hashCode() - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
hashCode() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.Histogram
 
hashCode() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
hashCode() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
hashCode() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
hashCode() - Method in class org.apache.druid.query.BaseQuery
 
hashCode() - Method in class org.apache.druid.query.BySegmentResultValueClass
 
hashCode() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataResultValue
 
hashCode() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
hashCode() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
hashCode() - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
hashCode() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
hashCode() - Method in class org.apache.druid.query.dimension.PrefixFilteredDimensionSpec
 
hashCode() - Method in class org.apache.druid.query.dimension.RegexFilteredDimensionSpec
 
hashCode() - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
 
hashCode() - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.LowerExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
hashCode() - Method in class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.StrlenExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
hashCode() - Method in class org.apache.druid.query.extraction.UpperExtractionFn
 
hashCode() - Method in class org.apache.druid.query.filter.AndDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.FalseDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.FilterTuning
 
hashCode() - Method in class org.apache.druid.query.filter.InDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.InDimFilter.InFilterDruidPredicateFactory
 
hashCode() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
hashCode() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
 
hashCode() - Method in class org.apache.druid.query.filter.NotDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.OrDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
 
hashCode() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
hashCode() - Method in class org.apache.druid.query.filter.TrueDimFilter
 
hashCode() - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
 
hashCode() - Method in class org.apache.druid.query.groupby.epinephelinae.Grouper.Entry
 
hashCode() - Method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey
 
hashCode() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
hashCode() - Method in class org.apache.druid.query.groupby.having.AndHavingSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.having.EqualToHavingSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.having.LessThanHavingSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.having.NotHavingSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.having.OrHavingSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
hashCode() - Method in class org.apache.druid.query.groupby.ResultRow
 
hashCode() - Method in class org.apache.druid.query.InlineDataSource
 
hashCode() - Method in class org.apache.druid.query.JoinDataSource
 
hashCode() - Method in class org.apache.druid.query.lookup.LookupConfig
 
hashCode() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
hashCode() - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
 
hashCode() - Method in class org.apache.druid.query.lookup.LookupsState
 
hashCode() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
hashCode() - Method in class org.apache.druid.query.LookupDataSource
 
hashCode() - Method in class org.apache.druid.query.metadata.metadata.AllColumnIncluderator
 
hashCode() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
hashCode() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
Best-effort hashCode method; relies on AggregatorFactory.hashCode, which is not guaranteed to be sanely implemented.
hashCode() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
hashCode() - Method in class org.apache.druid.query.MetricValueExtractor
 
hashCode() - Method in class org.apache.druid.query.ordering.StringComparators.AlphanumericComparator
 
hashCode() - Method in class org.apache.druid.query.ordering.StringComparators.LexicographicComparator
 
hashCode() - Method in class org.apache.druid.query.ordering.StringComparators.NumericComparator
 
hashCode() - Method in class org.apache.druid.query.ordering.StringComparators.StrlenComparator
 
hashCode() - Method in class org.apache.druid.query.ordering.StringComparators.VersionComparator
 
hashCode() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
 
hashCode() - Method in class org.apache.druid.query.planning.PreJoinableClause
 
hashCode() - Method in class org.apache.druid.query.QueryDataSource
 
hashCode() - Method in class org.apache.druid.query.Result
 
hashCode() - Method in class org.apache.druid.query.scan.ScanQuery
 
hashCode() - Method in class org.apache.druid.query.scan.ScanQueryConfig
 
hashCode() - Method in class org.apache.druid.query.scan.ScanResultValue
 
hashCode() - Method in class org.apache.druid.query.search.AllSearchQuerySpec
 
hashCode() - Method in class org.apache.druid.query.search.ContainsSearchQuerySpec
 
hashCode() - Method in class org.apache.druid.query.search.FragmentSearchQuerySpec
 
hashCode() - Method in class org.apache.druid.query.search.RegexSearchQuerySpec
 
hashCode() - Method in class org.apache.druid.query.search.SearchHit
 
hashCode() - Method in class org.apache.druid.query.search.SearchQuery
 
hashCode() - Method in class org.apache.druid.query.search.SearchResultValue
 
hashCode() - Method in class org.apache.druid.query.search.SearchSortSpec
 
hashCode() - Method in class org.apache.druid.query.spec.MultipleIntervalSegmentSpec
 
hashCode() - Method in class org.apache.druid.query.spec.MultipleSpecificSegmentSpec
 
hashCode() - Method in class org.apache.druid.query.spec.SpecificSegmentSpec
 
hashCode() - Method in class org.apache.druid.query.TableDataSource
 
hashCode() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
hashCode() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
 
hashCode() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
hashCode() - Method in class org.apache.druid.query.topn.DimensionAndMetricValueExtractor
 
hashCode() - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
hashCode() - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
hashCode() - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
hashCode() - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
hashCode() - Method in class org.apache.druid.query.topn.TopNQuery
 
hashCode() - Method in class org.apache.druid.query.topn.TopNResultValue
 
hashCode() - Method in class org.apache.druid.query.UnionDataSource
 
hashCode() - Method in class org.apache.druid.segment.column.RowSignature
 
hashCode() - Method in class org.apache.druid.segment.data.ConciseBitmapSerdeFactory
 
hashCode() - Method in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
 
hashCode() - Method in class org.apache.druid.segment.filter.AndFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.BoundFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.FalseFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.LikeFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.NotFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.OrFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.RegexFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.SearchQueryFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.SelectorFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.SpatialFilter
 
hashCode() - Method in class org.apache.druid.segment.filter.TrueFilter
 
hashCode() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
hashCode() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
 
hashCode() - Method in class org.apache.druid.segment.IndexSpec
 
hashCode() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
 
hashCode() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysisKey
 
hashCode() - Method in class org.apache.druid.segment.join.filter.JoinFilterSplit
 
hashCode() - Method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
 
hashCode() - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidate
 
hashCode() - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidates
 
hashCode() - Method in class org.apache.druid.segment.join.JoinableClause
 
hashCode() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
 
hashCode() - Method in class org.apache.druid.segment.loading.BroadcastJoinableMMappedQueryableSegmentizerFactory
 
hashCode() - Method in class org.apache.druid.segment.Metadata
 
hashCode() - Method in class org.apache.druid.segment.TimeAndDimsPointer
 
hashCode() - Method in class org.apache.druid.segment.transform.ExpressionTransform
 
hashCode() - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
hashCode() - Method in class org.apache.druid.segment.transform.TransformSpec
 
hashCode() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
hashCode() - Method in class org.apache.druid.segment.VirtualColumns
 
hashFunction() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
hashFunction() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
hashFunction() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
 
hashFunction() - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper
 
HashJoinEngine - Class in org.apache.druid.segment.join
 
HashJoinSegment - Class in org.apache.druid.segment.join
Represents a deep, left-heavy join of a left-hand side baseSegment onto a series of right-hand side clauses.
HashJoinSegment(SegmentReference, List<JoinableClause>, JoinFilterPreAnalysis) - Constructor for class org.apache.druid.segment.join.HashJoinSegment
 
HashJoinSegmentStorageAdapter - Class in org.apache.druid.segment.join
 
hashMemory(Memory, long, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.collection.HashTableUtils
Compute a simple, fast hash code of some memory range.
hashObject(Object) - Static method in class org.apache.druid.query.groupby.epinephelinae.Groupers
 
hashRow(ValueSelectorType, Hasher) - Method in interface org.apache.druid.query.aggregation.cardinality.types.CardinalityAggregatorColumnSelectorStrategy
Retrieve the current row from dimSelector and add the row values to the hasher.
hashRow(BaseDoubleColumnValueSelector, Hasher) - Method in class org.apache.druid.query.aggregation.cardinality.types.DoubleCardinalityAggregatorColumnSelectorStrategy
 
hashRow(BaseFloatColumnValueSelector, Hasher) - Method in class org.apache.druid.query.aggregation.cardinality.types.FloatCardinalityAggregatorColumnSelectorStrategy
 
hashRow(BaseLongColumnValueSelector, Hasher) - Method in class org.apache.druid.query.aggregation.cardinality.types.LongCardinalityAggregatorColumnSelectorStrategy
 
hashRow(DimensionSelector, Hasher) - Method in class org.apache.druid.query.aggregation.cardinality.types.StringCardinalityAggregatorColumnSelectorStrategy
 
hashTable - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
hashTableBuffer - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
hashTableFull(int) - Static method in class org.apache.druid.query.groupby.epinephelinae.Groupers
 
HashTableUtils - Class in org.apache.druid.query.groupby.epinephelinae.collection
 
hashValues(ValueSelectorType, HyperLogLogCollector) - Method in interface org.apache.druid.query.aggregation.cardinality.types.CardinalityAggregatorColumnSelectorStrategy
Retrieve the current row from dimSelector and add the row values to HyperLogLogCollector.
hashValues(BaseDoubleColumnValueSelector, HyperLogLogCollector) - Method in class org.apache.druid.query.aggregation.cardinality.types.DoubleCardinalityAggregatorColumnSelectorStrategy
 
hashValues(BaseFloatColumnValueSelector, HyperLogLogCollector) - Method in class org.apache.druid.query.aggregation.cardinality.types.FloatCardinalityAggregatorColumnSelectorStrategy
 
hashValues(BaseLongColumnValueSelector, HyperLogLogCollector) - Method in class org.apache.druid.query.aggregation.cardinality.types.LongCardinalityAggregatorColumnSelectorStrategy
 
hashValues(DimensionSelector, HyperLogLogCollector) - Method in class org.apache.druid.query.aggregation.cardinality.types.StringCardinalityAggregatorColumnSelectorStrategy
 
HashVectorGrouper - Class in org.apache.druid.query.groupby.epinephelinae
An implementation of VectorGrouper backed by a growable MemoryOpenHashTable.
HashVectorGrouper(Supplier<ByteBuffer>, int, AggregatorAdapters, int, float, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
 
hasLowerBound() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
hasMatch() - Method in interface org.apache.druid.segment.join.JoinMatcher
Returns whether the active matcher (JoinMatcher.matchCondition() or JoinMatcher.matchRemainder()) has matched something.
hasMatch() - Method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
 
hasMatch() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinMatcher
 
hasMultipleValues(String) - Method in interface org.apache.druid.query.filter.BitmapIndexSelector
 
hasMultipleValues() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
String columns are sneaky, and might have multiple values, this is to allow callers to know and appropriately prepare themselves
hasMultipleValues() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
hasMultipleValues() - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
hasMultipleValues() - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
hasMultipleValues(String) - Method in class org.apache.druid.segment.ColumnSelectorBitmapIndexSelector
 
hasNext() - Method in class org.apache.druid.collections.bitmap.BatchIteratorAdapter
 
hasNext() - Method in class org.apache.druid.collections.bitmap.PeekableIteratorAdapter
 
hasNext() - Method in class org.apache.druid.collections.IntegerSet.BitSetIterator
 
hasNext() - Method in class org.apache.druid.query.groupby.epinephelinae.CloseableGrouperIterator
 
hasNext() - Method in class org.apache.druid.query.scan.ScanQueryLimitRowIterator
 
hasNext() - Method in class org.apache.druid.segment.IndexMerger.DictionaryMergeIterator
 
hasNext() - Method in class org.apache.druid.segment.join.table.SortedIntIntersectionIterator
 
hasNulls() - Method in interface org.apache.druid.segment.column.BitmapIndex
 
hasNulls() - Method in interface org.apache.druid.segment.column.ColumnCapabilities.CoercionLogic
If ColumnCapabilities.hasNulls() is ColumnCapabilities.Capable.UNKNOWN, define if it should be treated as true or false
hasNulls() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
Does this column contain null values? If so, callers, especially for primitive numeric columns, will need to check for null value rows and act accordingly
hasNulls() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
hasParseException() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
hasQueryGranularity() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
hasRollup() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
hasSpatialIndexes() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
Does the column have spatial indexes available to allow use with spatial filtering?
hasSpatialIndexes() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
hasTimeAndDimsChangedSinceMark() - Method in class org.apache.druid.segment.ForwardingRowIterator
 
hasTimeAndDimsChangedSinceMark() - Method in interface org.apache.druid.segment.RowIterator
Compares the "memoized" data point from the last RowIterator.mark() call with the data point, to which RowIterator.getPointer() currently points.
hasTimeout(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
hasTimestampSpec() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
hasUpperBound() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
HavingSpec - Interface in org.apache.druid.query.groupby.having
A "having" clause that filters aggregated/dimension value.
HavingSpecUtil - Class in org.apache.druid.query.groupby.having
 
HavingSpecUtil() - Constructor for class org.apache.druid.query.groupby.having.HavingSpecUtil
 
HEADER_NUM_BYTES - Static variable in class org.apache.druid.collections.spatial.ImmutableNode
 
HeapBasedTopNAlgorithm - Class in org.apache.druid.query.topn
Heap based topn algorithm that handles aggregates on dimension extractions and numeric typed dimension columns.
HeapBasedTopNAlgorithm(StorageAdapter, TopNQuery) - Constructor for class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
HeapByteBufferWriteOutBytes - Class in org.apache.druid.segment.writeout
 
HeapByteBufferWriteOutBytes() - Constructor for class org.apache.druid.segment.writeout.HeapByteBufferWriteOutBytes
 
HIST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
Histogram - Class in org.apache.druid.query.aggregation
 
Histogram(float[]) - Constructor for class org.apache.druid.query.aggregation.Histogram
 
Histogram(float[], long[], float, float) - Constructor for class org.apache.druid.query.aggregation.Histogram
 
Histogram(Histogram) - Constructor for class org.apache.druid.query.aggregation.Histogram
 
HISTOGRAM_BUCKETS - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HISTOGRAM_CUSTOM_BUCKETS - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HISTOGRAM_EQUAL_BUCKETS - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HISTOGRAM_MAX - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HISTOGRAM_MIN - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HISTOGRAM_QUANTILE - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HISTOGRAM_QUANTILES - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HistogramAggregator - Class in org.apache.druid.query.aggregation
 
HistogramAggregator(BaseFloatColumnValueSelector, float[]) - Constructor for class org.apache.druid.query.aggregation.HistogramAggregator
 
HistogramAggregatorFactory - Class in org.apache.druid.query.aggregation
 
HistogramAggregatorFactory(String, String, List<Float>) - Constructor for class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
HistogramBufferAggregator - Class in org.apache.druid.query.aggregation
 
HistogramBufferAggregator(BaseFloatColumnValueSelector, float[]) - Constructor for class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
HistogramVisual - Class in org.apache.druid.query.aggregation
 
HistogramVisual(double[], double[], double[]) - Constructor for class org.apache.druid.query.aggregation.HistogramVisual
 
HistogramVisual(float[], float[], float[]) - Constructor for class org.apache.druid.query.aggregation.HistogramVisual
 
Historical1AggPooledTopNScanner<DimensionSelectorType extends HistoricalDimensionSelector,MetricSelectorType,BufferAggregatorType extends BufferAggregator> - Interface in org.apache.druid.query.topn
 
Historical1SimpleDoubleAggPooledTopNScannerPrototype - Class in org.apache.druid.query.topn
 
Historical1SimpleDoubleAggPooledTopNScannerPrototype() - Constructor for class org.apache.druid.query.topn.Historical1SimpleDoubleAggPooledTopNScannerPrototype
 
HistoricalColumnSelector<T> - Interface in org.apache.druid.segment.historical
 
HistoricalCursor - Interface in org.apache.druid.segment.historical
 
HistoricalDimensionSelector - Interface in org.apache.druid.segment.historical
Specialization for DimensionSelector queryable via offsets from HistoricalCursor.
HistoricalSingleValueDimSelector1SimpleDoubleAggPooledTopNScannerPrototype - Class in org.apache.druid.query.topn
 
HistoricalSingleValueDimSelector1SimpleDoubleAggPooledTopNScannerPrototype() - Constructor for class org.apache.druid.query.topn.HistoricalSingleValueDimSelector1SimpleDoubleAggPooledTopNScannerPrototype
 
HiveCnfHelper - Class in org.apache.druid.segment.filter.cnf
All functions in this class were basically adopted from Apache Hive and modified to use them in Druid.
HLL_HYPER_UNIQUE_FINALIZING - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HLL_SKETCH_BUILD_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
HLL_SKETCH_MERGE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
HLL_SKETCH_TO_ESTIMATE_AND_BOUNDS_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
HLL_SKETCH_TO_ESTIMATE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
HLL_SKETCH_TO_STRING_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
HLL_SKETCH_UNION_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
HotLoopCallee - Interface in org.apache.druid.query.monomorphicprocessing
Marker interface for abstractions, which are called from hot loops during query processing.
HYPER_UNIQUE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
HyperLogLogCollectorAggregateCombiner - Class in org.apache.druid.query.aggregation.cardinality
 
HyperLogLogCollectorAggregateCombiner() - Constructor for class org.apache.druid.query.aggregation.cardinality.HyperLogLogCollectorAggregateCombiner
 
HyperUniqueFinalizingPostAggregator - Class in org.apache.druid.query.aggregation.hyperloglog
 
HyperUniqueFinalizingPostAggregator(String, String) - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
HyperUniquesAggregator - Class in org.apache.druid.query.aggregation.hyperloglog
 
HyperUniquesAggregator(BaseObjectColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
 
HyperUniquesAggregatorFactory - Class in org.apache.druid.query.aggregation.hyperloglog
 
HyperUniquesAggregatorFactory(String, String, boolean, boolean) - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
HyperUniquesAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
HyperUniquesBufferAggregator - Class in org.apache.druid.query.aggregation.hyperloglog
 
HyperUniquesBufferAggregator(BaseObjectColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
HyperUniquesSerde - Class in org.apache.druid.query.aggregation.hyperloglog
 
HyperUniquesSerde() - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
 
HyperUniquesSerde(HyperLogLogHash) - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
 
HyperUniquesVectorAggregator - Class in org.apache.druid.query.aggregation.hyperloglog
 
HyperUniquesVectorAggregator(VectorObjectSelector) - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesVectorAggregator
 

I

ID - Static variable in class org.apache.druid.query.DruidMetrics
 
identity() - Static method in class org.apache.druid.query.aggregation.MetricManipulatorFns
 
identity(String) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
identity(String) - Method in interface org.apache.druid.query.QueryMetrics
Sets identity of the requester for a query.
identity(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
IdentityExtractionFn - Class in org.apache.druid.query.extraction
 
idLookup() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
idLookup() - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
idLookup() - Method in interface org.apache.druid.segment.DimensionDictionarySelector
Returns IdLookup if available for this DimensionSelector, or null.
IdLookup - Interface in org.apache.druid.segment
"Mixin" for DimensionSelector.
idLookup() - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
idLookup() - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
idLookup() - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
idLookup() - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
idLookup() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
idLookup() - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
idLookup() - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
ignoreAfterThreshold() - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm.BaseArrayProvider
 
ignoreAfterThreshold() - Method in interface org.apache.druid.query.topn.TopNMetricSpecBuilder
 
ignoreFirstN(int) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm.BaseArrayProvider
 
ignoreFirstN(int) - Method in interface org.apache.druid.query.topn.TopNMetricSpecBuilder
 
ImmutableBitmap - Interface in org.apache.druid.collections.bitmap
This class is meant to represent a simple wrapper around an immutable bitmap class.
ImmutableBitmapValues - Class in org.apache.druid.segment.data
 
ImmutableBitmapValues(ImmutableBitmap) - Constructor for class org.apache.druid.segment.data.ImmutableBitmapValues
 
ImmutableNode - Class in org.apache.druid.collections.spatial
Byte layout: Header 0 to 1 : the MSB is a boolean flag for isLeaf, the next 15 bits represent the number of children of a node Body 2 to 2 + numDims * Float.BYTES : minCoordinates 2 + numDims * Float.BYTES to 2 + 2 * numDims * Float.BYTES : maxCoordinates concise set rest (children) : Every 4 bytes is storing an offset representing the position of a child.
ImmutableNode(int, int, int, ByteBuffer, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.ImmutableNode
 
ImmutableNode(int, int, int, short, boolean, ByteBuffer, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.ImmutableNode
 
ImmutablePoint - Class in org.apache.druid.collections.spatial
 
ImmutablePoint(int, int, int, ByteBuffer, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.ImmutablePoint
 
ImmutablePoint(ImmutableNode) - Constructor for class org.apache.druid.collections.spatial.ImmutablePoint
 
ImmutableRTree - Class in org.apache.druid.collections.spatial
An immutable representation of an RTree for spatial indexing.
ImmutableRTree(ByteBuffer, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.ImmutableRTree
 
ImmutableRTreeObjectStrategy - Class in org.apache.druid.segment.data
 
ImmutableRTreeObjectStrategy(BitmapFactory) - Constructor for class org.apache.druid.segment.data.ImmutableRTreeObjectStrategy
 
include(String) - Method in class org.apache.druid.query.metadata.metadata.AllColumnIncluderator
 
include(String) - Method in interface org.apache.druid.query.metadata.metadata.ColumnIncluderator
 
include(String) - Method in class org.apache.druid.query.metadata.metadata.ListColumnIncluderator
 
include(String) - Method in class org.apache.druid.query.metadata.metadata.NoneColumnIncluderator
 
includesColumn(String) - Method in class org.apache.druid.segment.join.JoinableClause
Returns whether "columnName" can be retrieved from the Joinable represented by this clause (i.e., whether it starts with prefix and has at least one other character beyond that).
increment() - Method in class org.apache.druid.segment.BitmapOffset
 
increment() - Method in class org.apache.druid.segment.data.Offset
 
increment() - Method in class org.apache.druid.segment.FilteredOffset
 
increment() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset
 
increment() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
Increment the reference count by one.
increment() - Method in class org.apache.druid.segment.RowNumCounter
 
increment() - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
increment() - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
IncrementalIndex<AggregatorType> - Class in org.apache.druid.segment.incremental
 
IncrementalIndex(IncrementalIndexSchema, boolean, boolean) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndex
Setting deserializeComplexMetrics to false is necessary for intermediate aggregation such as groupBy that should not deserialize input columns using ComplexMetricSerde for aggregators that return complex metrics.
IncrementalIndex.Builder - Class in org.apache.druid.segment.incremental
 
IncrementalIndex.DimensionDesc - Class in org.apache.druid.segment.incremental
 
IncrementalIndex.MetricDesc - Class in org.apache.druid.segment.incremental
 
IncrementalIndexAdapter - Class in org.apache.druid.segment.incremental
 
IncrementalIndexAdapter(Interval, IncrementalIndex<?>, BitmapFactory) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexAdapter
 
IncrementalIndexAddResult - Class in org.apache.druid.segment.incremental
 
IncrementalIndexAddResult(int, long, ParseException) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
IncrementalIndexAddResult(int, long, String) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
IncrementalIndexAddResult(int, long) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
IncrementalIndexRow - Class in org.apache.druid.segment.incremental
 
IncrementalIndexRowHolder - Class in org.apache.druid.segment.incremental
IncrementalIndexRowHolder() - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
 
IncrementalIndexSchema - Class in org.apache.druid.segment.incremental
 
IncrementalIndexSchema(long, TimestampSpec, Granularity, VirtualColumns, DimensionsSpec, AggregatorFactory[], boolean) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexSchema
 
IncrementalIndexSchema.Builder - Class in org.apache.druid.segment.incremental
 
IncrementalIndexSegment - Class in org.apache.druid.segment
 
IncrementalIndexSegment(IncrementalIndex, SegmentId) - Constructor for class org.apache.druid.segment.IncrementalIndexSegment
 
IncrementalIndexStorageAdapter - Class in org.apache.druid.segment.incremental
 
IncrementalIndexStorageAdapter(IncrementalIndex<?>) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
incrementProcessed() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
incrementProcessed() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
incrementProcessedWithError() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
incrementProcessedWithError() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
incrementReferenceAndDecrementOnceCloseable() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
Returns an Optional of a Closeable from ReferenceCountingCloseableObject.decrementOnceCloseable(), if it is able to successfully ReferenceCountingCloseableObject.increment(), else nothing indicating that the reference could not be acquired.
incrementThrownAway() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
incrementThrownAway() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
incrementUnparseable() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
incrementUnparseable() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
IndexableAdapter - Interface in org.apache.druid.segment
An adapter to an index
Indexed<T> - Interface in org.apache.druid.segment.data
 
IndexedInts - Interface in org.apache.druid.segment.data
Get a int an index (array or list lookup abstraction without boxing).
IndexedIterable<T> - Class in org.apache.druid.segment.data
 
IndexedIterable(Indexed<T>) - Constructor for class org.apache.druid.segment.data.IndexedIterable
 
IndexedTable - Interface in org.apache.druid.segment.join.table
An interface to a table where some columns (the 'key columns') have indexes that enable fast lookups.
IndexedTable.Index - Interface in org.apache.druid.segment.join.table
Indexes support fast lookups on key columns.
IndexedTable.Reader - Interface in org.apache.druid.segment.join.table
Readers support reading values out of any column.
IndexedTableColumnSelectorFactory - Class in org.apache.druid.segment.join.table
 
IndexedTableColumnValueSelector - Class in org.apache.druid.segment.join.table
 
IndexedTableDimensionSelector - Class in org.apache.druid.segment.join.table
 
IndexedTableJoinable - Class in org.apache.druid.segment.join.table
 
IndexedTableJoinable(IndexedTable) - Constructor for class org.apache.druid.segment.join.table.IndexedTableJoinable
 
IndexedTableJoinMatcher - Class in org.apache.druid.segment.join.table
 
IndexIO - Class in org.apache.druid.segment
 
IndexIO(ObjectMapper, ColumnConfig) - Constructor for class org.apache.druid.segment.IndexIO
 
IndexIO.DefaultIndexIOHandler - Class in org.apache.druid.segment
 
IndexMerger - Interface in org.apache.druid.segment
 
IndexMerger.DictionaryMergeIterator - Class in org.apache.druid.segment
 
IndexMerger.IndexSeeker - Interface in org.apache.druid.segment
 
IndexMerger.IndexSeekerWithConversion - Class in org.apache.druid.segment
Get old dictId from new dictId, and only support access in order
IndexMergerV9 - Class in org.apache.druid.segment
 
IndexMergerV9(ObjectMapper, IndexIO, SegmentWriteOutMediumFactory) - Constructor for class org.apache.druid.segment.IndexMergerV9
 
indexOf(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
indexOf(String) - Method in class org.apache.druid.segment.column.RowSignature
Returns the first position of columnName in this row signature, or -1 if it does not appear.
indexOf(T) - Method in class org.apache.druid.segment.data.CachingIndexed
 
indexOf(IndexedInts) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
 
indexOf(T) - Method in class org.apache.druid.segment.data.GenericIndexed
Returns the index of "value" in this GenericIndexed object, or (-(insertion point) - 1) if the value is not present, in the manner of Arrays.binarySearch.
indexOf(T) - Method in interface org.apache.druid.segment.data.Indexed
Returns the index of "value" in this Indexed object, or a negative number if the value is not present.
indexOf(T) - Method in class org.apache.druid.segment.data.ListIndexed
 
indexOf(IndexedInts) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
IndexOnlyExecutor(SearchQuery, Segment, ImmutableBitmap, List<DimensionSpec>) - Constructor for class org.apache.druid.query.search.UseIndexesStrategy.IndexOnlyExecutor
 
IndexSeekerWithoutConversion(int) - Constructor for class org.apache.druid.segment.StringDimensionMergerV9.IndexSeekerWithoutConversion
 
IndexSizeExceededException - Exception in org.apache.druid.segment.incremental
 
IndexSizeExceededException(String, Object...) - Constructor for exception org.apache.druid.segment.incremental.IndexSizeExceededException
 
IndexSpec - Class in org.apache.druid.segment
IndexSpec defines segment storage format options to be used at indexing time, such as bitmap type, and column compression formats.
IndexSpec() - Constructor for class org.apache.druid.segment.IndexSpec
Creates an IndexSpec with default parameters
IndexSpec(BitmapSerdeFactory, CompressionStrategy, CompressionStrategy, CompressionFactory.LongEncodingStrategy) - Constructor for class org.apache.druid.segment.IndexSpec
 
IndexSpec(BitmapSerdeFactory, CompressionStrategy, CompressionStrategy, CompressionFactory.LongEncodingStrategy, SegmentizerFactory) - Constructor for class org.apache.druid.segment.IndexSpec
Creates an IndexSpec with the given storage format settings.
indexSpec - Variable in class org.apache.druid.segment.NumericDimensionMergerV9
 
InDimFilter - Class in org.apache.druid.query.filter
 
InDimFilter(String, Set<String>, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.query.filter.InDimFilter
 
InDimFilter(String, Set<String>) - Constructor for class org.apache.druid.query.filter.InDimFilter
 
InDimFilter(String, Collection<String>, ExtractionFn) - Constructor for class org.apache.druid.query.filter.InDimFilter
This constructor should be called only in unit tests since accepting a Collection makes copying more likely.
InDimFilter.InFilterDruidPredicateFactory - Class in org.apache.druid.query.filter
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Initialize all aggregators.
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.NumericAnyBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.NumericAnyVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.NumericNilVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyVectorAggregator
 
init(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Initializes the buffer location Implementations of this method must initialize the byte buffer at the given position Implementations must not change the position, limit or mark of the given buffer This method must not exceed the number of bytes returned by AggregatorFactory.getMaxIntermediateSizeWithNulls() in the corresponding AggregatorFactory
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleMaxBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleMaxVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleMinBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleMinVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleSumBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleSumVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.NumericFirstBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatMaxBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatMaxVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatMinBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatMinVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatSumBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatSumVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.NumericLastBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMaxBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMaxVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMinBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMinVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongSumBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongSumVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
init(ByteBuffer, int) - Static method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericVectorAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
init(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.VectorAggregator
init() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
init() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
init() - Method in class org.apache.druid.query.groupby.epinephelinae.ConcurrentGrouper
 
init() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
Initialize the grouper.
init() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
init() - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
 
init() - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
 
INIT_POSITION_VALUE - Static variable in interface org.apache.druid.query.topn.TopNAlgorithm
 
initAggregateStore() - Method in class org.apache.druid.query.topn.types.DoubleTopNColumnAggregatesProcessor
 
initAggregateStore() - Method in class org.apache.druid.query.topn.types.FloatTopNColumnAggregatesProcessor
 
initAggregateStore() - Method in class org.apache.druid.query.topn.types.LongTopNColumnAggregatesProcessor
 
initAggregateStore() - Method in class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
 
initAggregateStore() - Method in interface org.apache.druid.query.topn.types.TopNColumnAggregatesProcessor
Initializes the underlying aggregates store to something nice and seleector type appropriate
initAggs(AggregatorFactory[], Supplier<InputRow>, boolean, boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
initAggs(AggregatorFactory[], Supplier<InputRow>, boolean, boolean) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
initAggs(AggregatorFactory[], Supplier<InputRow>, boolean, boolean) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
initBucket(int, Memory, int) - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Initialize a bucket with a particular key.
initColumnValues(ColumnValueSelector, int, Object[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DictionaryBuildingStringGroupByColumnSelectorStrategy
 
initColumnValues(ColumnValueSelector, int, Object[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
initColumnValues(ColumnValueSelector, int, Object[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
initColumnValues(ColumnValueSelector, int, Object[]) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
Retrieve a row object from the ColumnValueSelector and put it in valuess at columnIndex.
initColumnValues(ColumnValueSelector, int, Object[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
initColumnValues(ColumnValueSelector, int, Object[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
initColumnValues(ColumnValueSelector, int, Object[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 
initGroupingKeyColumnValue(int, int, Object, ByteBuffer, int[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
initGroupingKeyColumnValue(int, int, Object, ByteBuffer, int[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
initGroupingKeyColumnValue(int, int, Object, ByteBuffer, int[]) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
Read the first value within a row values object (e.
initGroupingKeyColumnValue(int, int, Object, ByteBuffer, int[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
initGroupingKeyColumnValue(int, int, Object, ByteBuffer, int[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
initGroupingKeyColumnValue(int, int, Object, ByteBuffer, int[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 
initialBuckets - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
initialBuckets - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
initializeNewBucketKey(int, ByteBuffer, int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
initTopNAlgorithmSelector(TopNAlgorithmSelector) - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
initTopNAlgorithmSelector(TopNAlgorithmSelector) - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
initTopNAlgorithmSelector(TopNAlgorithmSelector) - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
initTopNAlgorithmSelector(TopNAlgorithmSelector) - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
initTopNAlgorithmSelector(TopNAlgorithmSelector) - Method in interface org.apache.druid.query.topn.TopNMetricSpec
 
initTopNAlgorithmSelector(TopNAlgorithmSelector) - Method in class org.apache.druid.query.topn.TopNQuery
 
initVectorized(int) - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
initVectorized(int) - Method in class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
 
initVectorized(int) - Method in interface org.apache.druid.query.groupby.epinephelinae.VectorGrouper
Initialize the grouper.
InlineDataSource - Class in org.apache.druid.query
Represents an inline datasource, where the rows are embedded within the DataSource object itself.
inputSizeFn() - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
Returns a function that can convert the Object provided by the ComplexColumn created through deserializeColumn into a number of expected input bytes to produce that object.
InsensitiveContainsSearchQuerySpec - Class in org.apache.druid.query.search
 
InsensitiveContainsSearchQuerySpec(String) - Constructor for class org.apache.druid.query.search.InsensitiveContainsSearchQuerySpec
 
insert(float[], int) - Method in class org.apache.druid.collections.spatial.RTree
This description is from the original paper.
insert(float[], MutableBitmap) - Method in class org.apache.druid.collections.spatial.RTree
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in interface org.apache.druid.query.aggregation.AggregateCombiner
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.any.NumericAnyBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Implementations of this method should call inspector.visit() with all fields of this class, which meet two conditions: 1.
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.first.NumericFirstBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.last.NumericLastBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.SimpleLongBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in interface org.apache.druid.query.monomorphicprocessing.HotLoopCallee
Implementations of this method should call inspector.visit() with all fields of this class, which meet two conditions: 1.
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.BitmapOffset
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.column.DoublesColumn
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.column.FloatsColumn
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.column.LongsColumn
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.ConstantExprEvalSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.CachingIndexed
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.GenericIndexed
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.ListIndexed
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.RangeIndexedInts
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.SingleIndexedInt
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.SliceIndexedInts
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.ZeroIndexedInts
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.DoubleWrappingDimensionSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.FilteredOffset
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.FloatWrappingDimensionSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.join.PossiblyNullColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.join.table.IndexedTableColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.LongWrappingDimensionSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.NilColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in interface org.apache.druid.segment.selector.settable.SettableColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.selector.settable.SettableValueDoubleColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.selector.settable.SettableValueFloatColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.selector.settable.SettableValueLongColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
 
inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
INSTANCE - Static variable in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder.Serializer
 
instance() - Static method in class org.apache.druid.query.aggregation.NoopAggregator
 
instance() - Static method in class org.apache.druid.query.aggregation.NoopBufferAggregator
 
instance() - Static method in class org.apache.druid.query.aggregation.NoopVectorAggregator
 
instance() - Static method in class org.apache.druid.query.DefaultGenericQueryMetricsFactory
Should be used only in tests, directly or indirectly (e.
instance() - Static method in class org.apache.druid.query.extraction.StrlenExtractionFn
 
instance() - Static method in class org.apache.druid.query.filter.FalseDimFilter
 
instance() - Static method in class org.apache.druid.query.filter.TrueDimFilter
 
instance() - Static method in class org.apache.druid.query.filter.vector.VectorValueMatcherColumnProcessorFactory
 
instance() - Static method in class org.apache.druid.query.groupby.DefaultGroupByQueryMetricsFactory
instance() - Static method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
 
INSTANCE - Static variable in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
instance() - Static method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
instance() - Static method in class org.apache.druid.query.search.ConciseBitmapDecisionHelper
 
instance() - Static method in class org.apache.druid.query.search.DefaultSearchQueryMetricsFactory
 
instance() - Static method in class org.apache.druid.query.search.RoaringBitmapDecisionHelper
 
instance() - Static method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetricsFactory
instance() - Static method in class org.apache.druid.query.topn.DefaultTopNQueryMetricsFactory
instance() - Static method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
instance() - Static method in class org.apache.druid.segment.data.ZeroIndexedInts
 
instance() - Static method in class org.apache.druid.segment.filter.FalseFilter
 
instance() - Static method in class org.apache.druid.segment.filter.TrueFilter
 
instance() - Static method in class org.apache.druid.segment.NilColumnValueSelector
 
instance() - Static method in class org.apache.druid.segment.writeout.OffHeapMemorySegmentWriteOutMediumFactory
 
instance() - Static method in class org.apache.druid.segment.writeout.OnHeapMemorySegmentWriteOutMediumFactory
 
instance() - Static method in class org.apache.druid.segment.writeout.TmpFileSegmentWriteOutMediumFactory
 
InsufficientResourcesException - Exception in org.apache.druid.query
This exception is thrown when the requested operation cannot be completed due to a lack of available resources.
InsufficientResourcesException(String) - Constructor for exception org.apache.druid.query.InsufficientResourcesException
 
IntegerSet - Class in org.apache.druid.collections
 
IntegerSet.BitSetIterator - Class in org.apache.druid.collections
 
IntermediateColumnarLongsSerializer - Class in org.apache.druid.segment.data
Serializer that chooses optimal ColumnarLongs format dymamically, based on the values being written.
intermediateComputeSizeBytes() - Method in class org.apache.druid.query.DruidProcessingConfig
 
intermediateComputeSizeBytesConfigured() - Method in class org.apache.druid.query.DruidProcessingConfig
 
intersection(Iterable<ImmutableBitmap>) - Method in interface org.apache.druid.collections.bitmap.BitmapFactory
Compute the intersection (bitwise-AND) of a set of bitmaps.
intersection(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.collections.bitmap.BitSetBitmapFactory
 
intersection(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.collections.bitmap.ConciseBitmapFactory
 
intersection(ImmutableBitmap) - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
Compute the bitwise-and of this bitmap with another bitmap.
intersection(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
intersection(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
intersection(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
intersection(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
intersection(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
intersection(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
intersection(Iterable<T>) - Method in interface org.apache.druid.query.BitmapResultFactory
Delegates to BitmapFactory.intersection(Iterable) on the wrapped bitmaps, and returns a bitmap result wrapping the resulting intersection ImmutableBitmap.
intersection(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
interval(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
INTERVAL - Static variable in class org.apache.druid.query.DruidMetrics
 
interval(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.getIntervals() of the given query as dimension.
interval - Variable in class org.apache.druid.query.search.CursorOnlyStrategy.CursorBasedExecutor
 
interval(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
interval - Variable in class org.apache.druid.query.search.SearchStrategy
 
IntervalDimFilter - Class in org.apache.druid.query.filter
 
IntervalDimFilter(String, List<Interval>, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.query.filter.IntervalDimFilter
 
IntervalDimFilter(String, List<Interval>, ExtractionFn) - Constructor for class org.apache.druid.query.filter.IntervalDimFilter
 
intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
 
intervals(String) - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
 
intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
intervals(String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
intervals(List<Interval>) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
intervals(String) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
intervals(List<Interval>) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
intervals(String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
intervals(String) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
intervals(List<Interval>) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
intervals(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
intervals(List<Interval>) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
IntGrouper - Interface in org.apache.druid.query.groupby.epinephelinae
Grouper specialized for the primitive int type
IntGrouper.IntGrouperHashFunction - Interface in org.apache.druid.query.groupby.epinephelinae
 
IntIteratorUtils - Class in org.apache.druid.segment
 
IntListUtils - Class in org.apache.druid.segment
 
INVALID_ROW - Static variable in interface org.apache.druid.segment.IndexMerger
 
InvertedTopNMetricSpec - Class in org.apache.druid.query.topn
 
InvertedTopNMetricSpec(TopNMetricSpec) - Constructor for class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
IPv4AddressMatchExprMacro - Class in org.apache.druid.query.expression
Implements an expression that checks if an IPv4 address belongs to a particular subnet.
IPv4AddressMatchExprMacro() - Constructor for class org.apache.druid.query.expression.IPv4AddressMatchExprMacro
 
IPv4AddressParseExprMacro - Class in org.apache.druid.query.expression
Implements an expression that parses a string or long into an IPv4 address stored (as an unsigned int) in a long.
IPv4AddressParseExprMacro() - Constructor for class org.apache.druid.query.expression.IPv4AddressParseExprMacro
 
IPv4AddressStringifyExprMacro - Class in org.apache.druid.query.expression
Implements an expression that converts a long or a string into an IPv4 address dotted-decimal string.
IPv4AddressStringifyExprMacro() - Constructor for class org.apache.druid.query.expression.IPv4AddressStringifyExprMacro
 
is(ExpressionPlan.Trait...) - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
isAggregateAllMetrics() - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
 
isAggregateTopNMetricFirst() - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
 
isAllFalse() - Method in interface org.apache.druid.query.filter.vector.ReadableVectorMatch
Checks if this match has accepted *nothing*.
isAllFalse() - Method in class org.apache.druid.query.filter.vector.VectorMatch
 
isAllSingleValueDims(ColumnInspector, List<DimensionSpec>) - Static method in class org.apache.druid.query.groupby.epinephelinae.GroupByQueryEngineV2
Checks whether all "dimensions" are either single-valued, or if allowed, nonexistent.
isAllTrue(int) - Method in interface org.apache.druid.query.filter.vector.ReadableVectorMatch
Checks if this match has accepted every row in the vector.
isAllTrue(int) - Method in class org.apache.druid.query.filter.vector.VectorMatch
 
isAlwaysFalse() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
Return whether this condition is a constant that is always false.
isAlwaysTrue() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
Return whether this condition is a constant that is always true.
isApplyLimitPushDown() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
isApplyLimitPushDownToSegment() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
isAsMillis() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
isBaseColumn(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
Returns whether "column" will be selected from "baseAdapter".
isBucketUsed(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
isByRow() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
isBySegment(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
isBySegment(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
isCacheable(QueryType, boolean) - Method in interface org.apache.druid.query.CacheStrategy
Returns whether the given query is cacheable or not.
isCacheable() - Method in interface org.apache.druid.query.DataSource
Returns true if queries on this dataSource are cacheable at both the result level and per-segment level.
isCacheable(boolean) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Indicates if results from this query are cacheable or not.
isCacheable(boolean) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
isCacheable(boolean) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
isCacheable() - Method in class org.apache.druid.query.InlineDataSource
 
isCacheable() - Method in class org.apache.druid.query.JoinDataSource
 
isCacheable() - Method in class org.apache.druid.query.LookupDataSource
 
isCacheable() - Method in class org.apache.druid.query.QueryDataSource
 
isCacheable() - Method in class org.apache.druid.query.TableDataSource
 
isCacheable() - Method in class org.apache.druid.query.UnionDataSource
 
isCanPushDown() - Method in class org.apache.druid.segment.join.filter.JoinFilterAnalysis
 
isCaseSensitive() - Method in class org.apache.druid.query.search.ContainsSearchQuerySpec
 
isCaseSensitive() - Method in class org.apache.druid.query.search.FragmentSearchQuerySpec
 
isClosed() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
 
isConcrete() - Method in interface org.apache.druid.query.DataSource
Returns true if this datasource represents concrete data that can be scanned via a Segment adapter of some kind.
isConcrete() - Method in class org.apache.druid.query.InlineDataSource
 
isConcrete() - Method in class org.apache.druid.query.JoinDataSource
 
isConcrete() - Method in class org.apache.druid.query.LookupDataSource
 
isConcrete() - Method in class org.apache.druid.query.QueryDataSource
 
isConcrete() - Method in class org.apache.druid.query.TableDataSource
 
isConcrete() - Method in class org.apache.druid.query.UnionDataSource
 
isConcreteBased() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns true if this datasource can be computed by the core Druid query stack via a scan of a concrete base datasource.
isConcreteTableBased() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns true if this datasource is concrete-based (see DataSourceAnalysis.isConcreteBased(), and the base datasource is a TableDataSource or a UnionDataSource composed entirely of TableDataSource.
isConstant() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
 
isContiguous() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
isContiguous() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
isContiguous() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
isContiguous() - Method in interface org.apache.druid.segment.vector.ReadableVectorOffset
Checks if the current batch is a contiguous range or not.
isDescending() - Method in class org.apache.druid.query.BaseQuery
 
isDescending() - Method in interface org.apache.druid.query.Query
 
isDescending() - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
isDictionaryEncoded() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
Is the column dictionary encoded? If so, a DimensionDictionarySelector may be used instead of using a value selector, allowing algorithms to operate on primitive integer dictionary ids rather than the looked up dictionary values
isDictionaryEncoded() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
isDirectlyJoinable(DataSource) - Method in interface org.apache.druid.segment.join.JoinableFactory
Returns true if a Joinable **may** be created for a given DataSource, but is not a guarantee that JoinableFactory.build(org.apache.druid.query.DataSource, org.apache.druid.segment.join.JoinConditionAnalysis) will return a non-empty result.
isDirectlyJoinable(DataSource) - Method in class org.apache.druid.segment.join.MapJoinableFactory
 
isDirectRewrite() - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidate
A direct rewrite occurs when we filter on an RHS column that is also part of a join equicondition.
isDone() - Method in interface org.apache.druid.segment.Cursor
 
isDone() - Method in class org.apache.druid.segment.join.PostJoinCursor
 
isDone() - Method in class org.apache.druid.segment.RowBasedCursor
 
isDone() - Method in class org.apache.druid.segment.RowWalker
 
isDone() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
isDone() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
isDone() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
isDone() - Method in interface org.apache.druid.segment.vector.VectorCursor
Returns false if the cursor is readable, true if it has nothing left to read.
isDone() - Method in interface org.apache.druid.segment.vector.VectorOffset
Checks if iteration is "done", meaning the current batch of offsets is empty, and there are no more coming.
isDoneOrInterrupted() - Method in interface org.apache.druid.segment.Cursor
 
isDoneOrInterrupted() - Method in class org.apache.druid.segment.join.PostJoinCursor
 
isDoneOrInterrupted() - Method in class org.apache.druid.segment.RowBasedCursor
 
isEmpty() - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
 
isEmpty() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
isEmpty() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
isEmpty() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
isEmpty() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
isEmpty() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
isEmpty() - Method in class org.apache.druid.collections.IntegerSet
 
isEmpty(T) - Method in interface org.apache.druid.query.BitmapResultFactory
Checks that the wrapped bitmap is empty, see ImmutableBitmap.isEmpty().
isEmpty(ImmutableBitmap) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
isEmpty() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
isEnableFilterPushDown() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
isEnableFilterPushDown() - Method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
 
isEnableFilterRewrite() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
 
isEnableFilterRewrite() - Method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
 
isEnableRewriteValueColumnFilters() - Method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
 
isError() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
isFalse() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
isFifo() - Method in class org.apache.druid.query.DruidProcessingConfig
 
isFilterable() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
All Druid primitive columns support filtering, maybe with or without indexes, but by default complex columns do not support direct filtering, unless provided by through a custom implementation.
isFilterable() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
isFinalize() - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
isFinalize(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
isForceHashAggregation() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
isForcePushDownLimit() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
isForcePushDownNestedQuery() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
isGlobal() - Method in interface org.apache.druid.query.DataSource
Returns true if all servers have a full copy of this datasource.
isGlobal() - Method in class org.apache.druid.query.GlobalTableDataSource
 
isGlobal() - Method in class org.apache.druid.query.InlineDataSource
 
isGlobal() - Method in class org.apache.druid.query.JoinDataSource
 
isGlobal() - Method in class org.apache.druid.query.LookupDataSource
 
isGlobal() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns true if all servers have the ability to compute this datasource.
isGlobal() - Method in class org.apache.druid.query.QueryDataSource
 
isGlobal() - Method in class org.apache.druid.query.TableDataSource
 
isGlobal() - Method in class org.apache.druid.query.UnionDataSource
 
isGrandTotal() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
isHasExtractionFn() - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
 
isHasMultipleValues() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
isHasMultipleValues() - Method in class org.apache.druid.segment.column.ColumnDescriptor
 
isHasNulls() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
isInitialized() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
isInitialized() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
isInitialized() - Method in class org.apache.druid.query.groupby.epinephelinae.ConcurrentGrouper
 
isInitialized() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
Check this grouper is initialized or not.
isInitialized() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
isInitialized() - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
 
isInitialized() - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
 
isInjective() - Method in class org.apache.druid.query.extraction.FunctionalExtraction
 
isInjective() - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
isInjective() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
isInjective() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
isJoda() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
isLeaf() - Method in class org.apache.druid.collections.spatial.ImmutableNode
 
isLeaf() - Method in class org.apache.druid.collections.spatial.Node
 
isLeaf() - Method in class org.apache.druid.collections.spatial.Point
 
isLegacy() - Method in class org.apache.druid.query.scan.ScanQuery
Compatibility mode with the legacy scan-query extension.
isLegacy() - Method in class org.apache.druid.query.scan.ScanQueryConfig
 
isLenientAggregatorMerge() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
isLimited() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
isLimited() - Method in class org.apache.druid.query.scan.ScanQuery
Returns whether this query is limited or not.
isLowerStrict() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
isMaybeTrue() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
isMerge() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
isMetric() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
isNestedQueryPushDown(GroupByQuery, GroupByStrategy) - Static method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
isNilSelector(DimensionSelector) - Static method in interface org.apache.druid.segment.DimensionSelector
Checks if the given selector constantly returns null.
isNull() - Method in interface org.apache.druid.query.aggregation.AggregateCombiner
 
isNull() - Method in interface org.apache.druid.query.aggregation.Aggregator
returns true if aggregator's output type is primitive long/double/float and aggregated value is null, but when aggregated output type is Object, this method always returns false, and users are advised to check nullability for the object returned by Aggregator.get() method.
isNull(ByteBuffer, int) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
returns true if aggregator's output type is primitive long/double/float and aggregated value is null, but when aggregated output type is Object, this method always returns false, and users are advised to check nullability for the object returned by BufferAggregator.get(ByteBuffer, int) method.
isNull() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
 
isNull(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
isNull(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
isNull() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
isNull() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
 
isNull(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
isNull() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
isNull(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
isNull() - Method in interface org.apache.druid.segment.BaseNullableColumnValueSelector
Returns true if the primitive long, double, or float value returned by this selector should be treated as null.
isNull() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
 
isNull() - Method in interface org.apache.druid.segment.DimensionSelector
Deprecated.
isNull(int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
isNull() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
 
isNull(int, int) - Method in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
isNull(int, int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
isNull() - Method in class org.apache.druid.segment.join.PossiblyNullColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.join.table.IndexedTableColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.NilColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.ObjectColumnSelector
Deprecated.
This method is marked as deprecated in ObjectColumnSelector since it always returns false. There is no need to call this method.
isNull() - Method in class org.apache.druid.segment.selector.settable.SettableDoubleColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.selector.settable.SettableFloatColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.selector.settable.SettableLongColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.selector.settable.SettableValueDoubleColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.selector.settable.SettableValueFloatColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.selector.settable.SettableValueLongColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
 
isNull() - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
 
isOffset() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
isOffsetUsed(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
isOk() - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
True if all rows have been processed.
isOneToOne() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
isOneToOne() - Method in class org.apache.druid.query.lookup.LookupExtractor
 
isOpen() - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
isOptimize() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
isOptimize() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
isPopulateCache(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
isPopulateCache(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
isPopulateResultLevelCache(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
isPopulateResultLevelCache(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
isPrefixedBy(String, String) - Static method in class org.apache.druid.segment.join.Joinables
 
isQuery() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
Returns true if this datasource represents a subquery (that is, whether it is a QueryDataSource).
isReplaceMissingValue() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
isRetainAfterJoin() - Method in class org.apache.druid.segment.join.filter.JoinFilterAnalysis
 
isRetainMissingValue() - Method in class org.apache.druid.query.extraction.FunctionalExtraction
 
isRetainMissingValue() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
isRetainMissingValue() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
isRollup() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
isRollup() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
isRollup() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
 
isRollup() - Method in class org.apache.druid.segment.Metadata
 
isRound() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
isRound() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
isRowAdded() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
 
isSecondaryPartitionPruningEnabled(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
isSerializeDateTimeAsLong(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
isSerializeDateTimeAsLongInner(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
isShutdown() - Method in class org.apache.druid.query.PrioritizedExecutorService
 
isSingleThreaded() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
isSkipEmptyBuckets() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
isSupportConnected() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
isTerminated() - Method in class org.apache.druid.query.PrioritizedExecutorService
 
isTrue() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
isTruncated() - Method in class org.apache.druid.query.context.ResponseContext.SerializationResult
 
isUnknown() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
isUpperStrict() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
isUseCache(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
isUseCache(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
isUseExtensionClassloaderFirst() - Method in class org.apache.druid.guice.ExtensionsConfig
 
isUseResultLevelCache(Query<T>) - Static method in class org.apache.druid.query.QueryContexts
 
isUseResultLevelCache(Query<T>, boolean) - Static method in class org.apache.druid.query.QueryContexts
 
isUsingDefaultInterval() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
isValid(ReadableVectorMatch) - Method in interface org.apache.druid.query.filter.vector.ReadableVectorMatch
Checks if this match is valid (increasing row numbers, no out-of-range row numbers).
isValid(ReadableVectorMatch) - Method in class org.apache.druid.query.filter.vector.VectorMatch
 
isVectorize() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
isWhitelist() - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
isWithRollup() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
 
iterable() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
iterable() - Method in class org.apache.druid.query.lookup.LookupExtractor
Returns an Iterable that iterates over the keys and values in this lookup extractor.
iterableWithPostAggregations(List<PostAggregator>, boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
iterator() - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
 
iterator() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
iterator() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
iterator() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
iterator() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
iterator() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
iterator() - Method in class org.apache.druid.collections.IntegerSet
 
iterator() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
iterator(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
iterator(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
iterator(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.ConcurrentGrouper
 
iterator(boolean) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
Iterate through entries.
iterator() - Method in class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
 
iterator(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
iterator(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
 
iterator() - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
Return a sorted iterator.
iterator(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
Return a sorted iterator.
iterator() - Method in interface org.apache.druid.query.groupby.epinephelinae.VectorGrouper
Iterate through entry buckets.
iterator() - Method in class org.apache.druid.query.search.SearchResultValue
 
iterator() - Method in class org.apache.druid.query.SinkQueryRunners
 
iterator() - Method in class org.apache.druid.query.topn.TopNResultValue
 
iterator() - Method in interface org.apache.druid.segment.data.BitmapValues
 
iterator() - Method in class org.apache.druid.segment.data.CachingIndexed
 
iterator() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
 
iterator() - Method in class org.apache.druid.segment.data.GenericIndexed
 
iterator() - Method in class org.apache.druid.segment.data.ImmutableBitmapValues
 
iterator() - Method in class org.apache.druid.segment.data.IndexedIterable
 
iterator() - Method in class org.apache.druid.segment.data.ListIndexed
 
iterator() - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
iterator() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
iterator() - Method in class org.apache.druid.segment.StringDimensionMergerV9.ConvertingBitmapValues
 

J

JacksonModule - Class in org.apache.druid.jackson
 
JacksonModule() - Constructor for class org.apache.druid.jackson.JacksonModule
 
JAVA_SCRIPT - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
JavaScriptAggregator - Class in org.apache.druid.query.aggregation
 
JavaScriptAggregator(List<BaseObjectColumnValueSelector>, JavaScriptAggregator.ScriptAggregator) - Constructor for class org.apache.druid.query.aggregation.JavaScriptAggregator
 
JavaScriptAggregatorFactory - Class in org.apache.druid.query.aggregation
 
JavaScriptAggregatorFactory(String, List<String>, String, String, String, JavaScriptConfig) - Constructor for class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
JavaScriptBufferAggregator - Class in org.apache.druid.query.aggregation
 
JavaScriptBufferAggregator(List<BaseObjectColumnValueSelector>, JavaScriptAggregator.ScriptAggregator) - Constructor for class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
 
JavaScriptDimFilter - Class in org.apache.druid.query.filter
 
JavaScriptDimFilter(String, String, ExtractionFn, FilterTuning, JavaScriptConfig) - Constructor for class org.apache.druid.query.filter.JavaScriptDimFilter
 
JavaScriptDimFilter(String, String, ExtractionFn, JavaScriptConfig) - Constructor for class org.apache.druid.query.filter.JavaScriptDimFilter
 
JavaScriptDimFilter.JavaScriptPredicateFactory - Class in org.apache.druid.query.filter
 
JavaScriptExtractionFn - Class in org.apache.druid.query.extraction
 
JavaScriptExtractionFn(String, boolean, JavaScriptConfig) - Constructor for class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
JavaScriptFilter - Class in org.apache.druid.segment.filter
 
JavaScriptFilter(String, JavaScriptDimFilter.JavaScriptPredicateFactory, FilterTuning) - Constructor for class org.apache.druid.segment.filter.JavaScriptFilter
 
JavaScriptPostAggregator - Class in org.apache.druid.query.aggregation.post
 
JavaScriptPostAggregator(String, List<String>, String, JavaScriptConfig) - Constructor for class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
 
JavaScriptPredicateFactory(String, ExtractionFn) - Constructor for class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
JOIN_FILTER_PUSH_DOWN_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
JOIN_FILTER_REWRITE_ENABLE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
JOIN_FILTER_REWRITE_MAX_SIZE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
JOIN_FILTER_REWRITE_VALUE_COLUMN_FILTERS_ENABLE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
Joinable - Interface in org.apache.druid.segment.join
Represents something that can be the right-hand side of a join.
JoinableClause - Class in org.apache.druid.segment.join
Represents everything about a join clause except for the left-hand datasource.
JoinableClause(String, Joinable, JoinType, JoinConditionAnalysis) - Constructor for class org.apache.druid.segment.join.JoinableClause
 
JoinableClauses - Class in org.apache.druid.segment.join.filter
 
JoinableFactory - Interface in org.apache.druid.segment.join
Utility for creating Joinable objects.
Joinables - Class in org.apache.druid.segment.join
Utility methods for working with Joinable related classes.
Joinables() - Constructor for class org.apache.druid.segment.join.Joinables
 
JoinConditionAnalysis - Class in org.apache.druid.segment.join
Represents analysis of a join condition.
JoinDataSource - Class in org.apache.druid.query
Represents a join of two datasources.
JoinFilterAnalysis - Class in org.apache.druid.segment.join.filter
Holds information about: - whether a filter can be pushed down - if it needs to be retained after the join, - a reference to the original filter - a potentially rewritten filter to be pushed down to the base table - a list of virtual columns that need to be created on the base table to support the pushed down filter
JoinFilterAnalysis(boolean, Filter, Filter) - Constructor for class org.apache.druid.segment.join.filter.JoinFilterAnalysis
 
JoinFilterAnalyzer - Class in org.apache.druid.segment.join.filter
When there is a filter in a join query, we can sometimes improve performance by applying parts of the filter when we first read from the base table instead of after the join.
JoinFilterAnalyzer() - Constructor for class org.apache.druid.segment.join.filter.JoinFilterAnalyzer
 
JoinFilterColumnCorrelationAnalysis - Class in org.apache.druid.segment.join.filter
Represents an analysis of what base table columns, if any, can be correlated with a column that will be filtered on.
JoinFilterColumnCorrelationAnalysis(String, Set<String>, Set<Expr>) - Constructor for class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
 
JoinFilterCorrelations - Class in org.apache.druid.segment.join.filter
A wrapper class for correlation analyses of different filters involved in the query.
JoinFilterPreAnalysis - Class in org.apache.druid.segment.join.filter
A JoinFilterPreAnalysis contains filter push down/rewrite information that does not have per-segment dependencies.
JoinFilterPreAnalysis.Builder - Class in org.apache.druid.segment.join.filter
A Builder class to build JoinFilterPreAnalysis
JoinFilterPreAnalysisKey - Class in org.apache.druid.segment.join.filter
All the information that is required to generate a JoinFilterPreAnalysis.
JoinFilterPreAnalysisKey(JoinFilterRewriteConfig, List<JoinableClause>, VirtualColumns, Filter) - Constructor for class org.apache.druid.segment.join.filter.JoinFilterPreAnalysisKey
 
JoinFilterRewriteConfig - Class in org.apache.druid.segment.join.filter.rewrite
A config class that holds properties that control how join filter rewrites behave.
JoinFilterRewriteConfig(boolean, boolean, boolean, long) - Constructor for class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
 
JoinFilterSplit - Class in org.apache.druid.segment.join.filter
Holds the result of splitting a filter into: - a portion that can be pushed down to the base table - a portion that will be applied post-join - additional virtual columns that need to be created on the base table to support the pushed down filters.
JoinFilterSplit(Filter, Filter, Set<VirtualColumn>) - Constructor for class org.apache.druid.segment.join.filter.JoinFilterSplit
 
JoinMatcher - Interface in org.apache.druid.segment.join
JoinType - Enum in org.apache.druid.segment.join
 
JS_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
jsonMapper() - Method in class org.apache.druid.jackson.JacksonModule
 

K

keepOnlyN(int) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm.BaseArrayProvider
 
keepOnlyN(int) - Method in interface org.apache.druid.query.topn.TopNMetricSpecBuilder
 
KEY_COLUMN - Static variable in class org.apache.druid.segment.join.lookup.LookupColumnSelectorFactory
 
keyClazz() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
Class of the keys.
keyColumns() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
keyColumns() - Method in interface org.apache.druid.segment.join.table.IndexedTable
Returns the columns of this table that have indexes.
keyColumns() - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
 
keyColumns() - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
keyOf(String) - Static method in enum org.apache.druid.query.context.ResponseContext.Key
Returns a registered key associated with the name .
keySerde - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
keySize - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
keySize - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
keySize() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the size of keys, in bytes.
keySize() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
Size of the keys returned by Grouper.KeySerde.toByteBuffer(Object) (which must be a fixed size)

L

LANE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
LargeColumnSupportedComplexColumnSerializer<T> - Class in org.apache.druid.segment.serde
 
lastTime - Variable in class org.apache.druid.query.aggregation.last.StringLastAggregator
 
lastValue - Variable in class org.apache.druid.query.aggregation.last.StringLastAggregator
 
LeftTrimExprMacro() - Constructor for class org.apache.druid.query.expression.TrimExprMacro.LeftTrimExprMacro
 
legacy(Boolean) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
LEGACY_FACTORY - Static variable in class org.apache.druid.segment.IndexIO
 
LEGACY_LONG_ENCODING_FORMAT - Static variable in class org.apache.druid.segment.data.CompressionFactory
 
LegacyBitmapSerdeFactory() - Constructor for class org.apache.druid.segment.data.BitmapSerde.LegacyBitmapSerdeFactory
 
LegacyDimensionSpec - Class in org.apache.druid.query.dimension
 
LegacyDimensionSpec(Object) - Constructor for class org.apache.druid.query.dimension.LegacyDimensionSpec
 
LegacySegmentSpec - Class in org.apache.druid.query.spec
 
LegacySegmentSpec(Object) - Constructor for class org.apache.druid.query.spec.LegacySegmentSpec
 
LegacyTopNMetricSpec - Class in org.apache.druid.query.topn
 
LegacyTopNMetricSpec(Object) - Constructor for class org.apache.druid.query.topn.LegacyTopNMetricSpec
 
length() - Method in class org.apache.druid.query.groupby.ResultRow
 
length() - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
length() - Method in class org.apache.druid.segment.column.DoublesColumn
 
length() - Method in class org.apache.druid.segment.column.FloatsColumn
 
length() - Method in class org.apache.druid.segment.column.LongsColumn
 
length() - Method in interface org.apache.druid.segment.column.NumericColumn
 
length() - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
lenientAggregatorMerge(boolean) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
LessThanHavingSpec - Class in org.apache.druid.query.groupby.having
The "<" operator in a "having" clause.
LessThanHavingSpec(String, Number) - Constructor for class org.apache.druid.query.groupby.having.LessThanHavingSpec
 
LEXICOGRAPHIC - Static variable in class org.apache.druid.query.ordering.StringComparators
 
LEXICOGRAPHIC_CACHE_ID - Static variable in class org.apache.druid.query.ordering.StringComparators
 
LEXICOGRAPHIC_NAME - Static variable in class org.apache.druid.query.ordering.StringComparators
 
LexicographicComparator() - Constructor for class org.apache.druid.query.ordering.StringComparators.LexicographicComparator
 
LexicographicTopNMetricSpec - Class in org.apache.druid.query.topn
 
LexicographicTopNMetricSpec(String) - Constructor for class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
LifecycleForkJoinPoolProvider - Class in org.apache.druid.guice
 
LifecycleForkJoinPoolProvider(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean, long) - Constructor for class org.apache.druid.guice.LifecycleForkJoinPoolProvider
 
LikeDimFilter - Class in org.apache.druid.query.filter
 
LikeDimFilter(String, String, String, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.query.filter.LikeDimFilter
 
LikeDimFilter(String, String, String, ExtractionFn) - Constructor for class org.apache.druid.query.filter.LikeDimFilter
 
LikeDimFilter.LikeMatcher - Class in org.apache.druid.query.filter
 
LikeDimFilter.LikeMatcher.SuffixMatch - Enum in org.apache.druid.query.filter
 
LikeExprMacro - Class in org.apache.druid.query.expression
 
LikeExprMacro() - Constructor for class org.apache.druid.query.expression.LikeExprMacro
 
LikeFilter - Class in org.apache.druid.segment.filter
 
LikeFilter(String, ExtractionFn, LikeDimFilter.LikeMatcher, FilterTuning) - Constructor for class org.apache.druid.segment.filter.LikeFilter
 
limit(long) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
limit(int) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
limit(int) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
limit(int) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.Builder
 
limit(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetrics
 
limit(TimeseriesQuery) - Method in interface org.apache.druid.query.timeseries.TimeseriesQueryMetrics
Sets TimeseriesQuery.getLimit() of the given query as dimension.
LimitedBufferHashGrouper<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
 
LimitedBufferHashGrouper(Supplier<ByteBuffer>, Grouper.KeySerde<KeyType>, AggregatorAdapters, int, float, int, int, boolean) - Constructor for class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
LimitedBufferHashGrouper.BufferGrouperOffsetHeapIndexUpdater - Class in org.apache.druid.query.groupby.epinephelinae
 
LimitedTemporaryStorage - Class in org.apache.druid.query.groupby.epinephelinae
An area for limited temporary storage on disk.
LimitedTemporaryStorage(File, long) - Constructor for class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage
 
LimitedTemporaryStorage.LimitedOutputStream - Class in org.apache.druid.query.groupby.epinephelinae
 
LimitSpec - Interface in org.apache.druid.query.groupby.orderby
 
LinearGutmanSplitStrategy - Class in org.apache.druid.collections.spatial.split
 
LinearGutmanSplitStrategy(int, int, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.split.LinearGutmanSplitStrategy
 
ListColumnIncluderator - Class in org.apache.druid.query.metadata.metadata
 
ListColumnIncluderator(List<String>) - Constructor for class org.apache.druid.query.metadata.metadata.ListColumnIncluderator
 
ListFilteredDimensionSpec - Class in org.apache.druid.query.dimension
 
ListFilteredDimensionSpec(DimensionSpec, Set<String>, Boolean) - Constructor for class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
ListIndexed<T> - Class in org.apache.druid.segment.data
 
ListIndexed(List<T>) - Constructor for class org.apache.druid.segment.data.ListIndexed
 
ListIndexed(T...) - Constructor for class org.apache.druid.segment.data.ListIndexed
 
loadDimensionIterable(Iterable<String>, Map<String, ColumnCapabilities>) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
Currently called to initialize IncrementalIndex dimension order during index creation Index dimension ordering could be changed to initialize from DimensionsSpec after resolution of https://github.com/apache/druid/issues/2011
loadIndex(File) - Method in class org.apache.druid.segment.IndexIO
 
loadIndex(File, boolean) - Method in class org.apache.druid.segment.IndexIO
 
log - Static variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
log - Static variable in interface org.apache.druid.segment.IndexMerger
 
LONG_ANY_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
LONG_COMPARATOR - Static variable in class org.apache.druid.segment.LongDimensionIndexer
 
LONG_FIRST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
LONG_GREATEST - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
LONG_LAST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
LONG_LEAST - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
LONG_MAX_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
LONG_MIN_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
LONG_SUM_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
LongAggregateCombiner - Class in org.apache.druid.query.aggregation
Specialization of AggregateCombiner for primitive long aggregations.
LongAggregateCombiner() - Constructor for class org.apache.druid.query.aggregation.LongAggregateCombiner
 
LongAnyAggregator - Class in org.apache.druid.query.aggregation.any
 
LongAnyAggregator(BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.LongAnyAggregator
 
LongAnyAggregatorFactory - Class in org.apache.druid.query.aggregation.any
 
LongAnyAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
LongAnyBufferAggregator - Class in org.apache.druid.query.aggregation.any
 
LongAnyBufferAggregator(BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.LongAnyBufferAggregator
 
LongAnyVectorAggregator - Class in org.apache.druid.query.aggregation.any
Vectorized implementation of the LongAnyBufferAggregator
LongAnyVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.LongAnyVectorAggregator
 
LongCardinalityAggregatorColumnSelectorStrategy - Class in org.apache.druid.query.aggregation.cardinality.types
If performance of this class appears to be a bottleneck for somebody, one simple way to improve it is to split it into two different classes, one that is used when NullHandling.replaceWithDefault() is false, and one - when it's true, moving this computation out of the tight loop
LongCardinalityAggregatorColumnSelectorStrategy() - Constructor for class org.apache.druid.query.aggregation.cardinality.types.LongCardinalityAggregatorColumnSelectorStrategy
 
LongColumnSelector - Interface in org.apache.druid.segment
This interface is convenient for implementation of "long-sourcing" ColumnValueSelectors, it provides default implementations for all ColumnValueSelector's methods except BaseLongColumnValueSelector.getLong().
LongColumnSerializer - Class in org.apache.druid.segment
Unsafe for concurrent use from multiple threads.
LongColumnSerializerV2 - Class in org.apache.druid.segment
Column Serializer for long column.
LongDimensionHandler - Class in org.apache.druid.segment
 
LongDimensionHandler(String) - Constructor for class org.apache.druid.segment.LongDimensionHandler
 
LongDimensionIndexer - Class in org.apache.druid.segment
 
LongDimensionIndexer() - Constructor for class org.apache.druid.segment.LongDimensionIndexer
 
LongDimensionMergerV9 - Class in org.apache.druid.segment
 
LongFirstAggregator - Class in org.apache.druid.query.aggregation.first
 
LongFirstAggregator(BaseLongColumnValueSelector, BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.first.LongFirstAggregator
 
LongFirstAggregatorFactory - Class in org.apache.druid.query.aggregation.first
 
LongFirstAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
LongFirstBufferAggregator - Class in org.apache.druid.query.aggregation.first
 
LongFirstBufferAggregator(BaseLongColumnValueSelector, BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.first.LongFirstBufferAggregator
 
LongGreatestPostAggregator - Class in org.apache.druid.query.aggregation.post
 
LongGreatestPostAggregator(String, List<PostAggregator>) - Constructor for class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
LongGroupByColumnSelectorStrategy - Class in org.apache.druid.query.groupby.epinephelinae.column
 
LongGroupByColumnSelectorStrategy() - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
LongGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
LongLastAggregator - Class in org.apache.druid.query.aggregation.last
 
LongLastAggregator(BaseLongColumnValueSelector, BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.last.LongLastAggregator
 
LongLastAggregatorFactory - Class in org.apache.druid.query.aggregation.last
 
LongLastAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
LongLastBufferAggregator - Class in org.apache.druid.query.aggregation.last
 
LongLastBufferAggregator(BaseLongColumnValueSelector, BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.last.LongLastBufferAggregator
 
LongLeastPostAggregator - Class in org.apache.druid.query.aggregation.post
 
LongLeastPostAggregator(String, List<PostAggregator>) - Constructor for class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
LongMaxAggregator - Class in org.apache.druid.query.aggregation
 
LongMaxAggregator(BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.LongMaxAggregator
 
LongMaxAggregatorFactory - Class in org.apache.druid.query.aggregation
 
LongMaxAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
LongMaxAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
LongMaxBufferAggregator - Class in org.apache.druid.query.aggregation
 
LongMaxVectorAggregator - Class in org.apache.druid.query.aggregation
 
LongMaxVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.LongMaxVectorAggregator
 
LongMinAggregator - Class in org.apache.druid.query.aggregation
 
LongMinAggregator(BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.LongMinAggregator
 
LongMinAggregatorFactory - Class in org.apache.druid.query.aggregation
 
LongMinAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
LongMinAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
LongMinBufferAggregator - Class in org.apache.druid.query.aggregation
 
LongMinVectorAggregator - Class in org.apache.druid.query.aggregation
 
LongMinVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.LongMinVectorAggregator
 
longNilVectorAggregator() - Static method in class org.apache.druid.query.aggregation.any.NumericNilVectorAggregator
 
LongNumericColumnPartSerde - Class in org.apache.druid.segment.serde
 
LongNumericColumnPartSerde.SerializerBuilder - Class in org.apache.druid.segment.serde
 
LongNumericColumnPartSerdeV2 - Class in org.apache.druid.segment.serde
 
LongNumericColumnPartSerdeV2.SerializerBuilder - Class in org.apache.druid.segment.serde
 
LongNumericColumnSupplier - Class in org.apache.druid.segment.serde
 
LongNumericColumnSupplier(CompressedColumnarLongsSupplier, ImmutableBitmap) - Constructor for class org.apache.druid.segment.serde.LongNumericColumnSupplier
 
LongsColumn - Class in org.apache.druid.segment.column
 
LongSearchColumnSelectorStrategy() - Constructor for class org.apache.druid.query.search.SearchQueryRunner.LongSearchColumnSelectorStrategy
 
LongsLongEncodingReader - Class in org.apache.druid.segment.data
 
LongsLongEncodingReader(ByteBuffer, ByteOrder) - Constructor for class org.apache.druid.segment.data.LongsLongEncodingReader
 
LongsLongEncodingWriter - Class in org.apache.druid.segment.data
 
LongsLongEncodingWriter(ByteOrder) - Constructor for class org.apache.druid.segment.data.LongsLongEncodingWriter
 
LongSumAggregateCombiner - Class in org.apache.druid.query.aggregation
 
LongSumAggregateCombiner() - Constructor for class org.apache.druid.query.aggregation.LongSumAggregateCombiner
 
LongSumAggregator - Class in org.apache.druid.query.aggregation
 
LongSumAggregator(BaseLongColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.LongSumAggregator
 
LongSumAggregatorFactory - Class in org.apache.druid.query.aggregation
 
LongSumAggregatorFactory(String, String, String, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
LongSumAggregatorFactory(String, String) - Constructor for class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
LongSumBufferAggregator - Class in org.apache.druid.query.aggregation
 
LongSumVectorAggregator - Class in org.apache.druid.query.aggregation
 
LongSumVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.LongSumVectorAggregator
 
LongTopNColumnAggregatesProcessor - Class in org.apache.druid.query.topn.types
 
LongTopNColumnAggregatesProcessor(Function<Object, Comparable<?>>) - Constructor for class org.apache.druid.query.topn.types.LongTopNColumnAggregatesProcessor
 
LongVectorValueMatcher - Class in org.apache.druid.query.filter.vector
 
LongVectorValueMatcher(VectorValueSelector) - Constructor for class org.apache.druid.query.filter.vector.LongVectorValueMatcher
 
LongWrappingDimensionSelector - Class in org.apache.druid.segment
 
LongWrappingDimensionSelector(BaseLongColumnValueSelector, ExtractionFn) - Constructor for class org.apache.druid.segment.LongWrappingDimensionSelector
 
lookup(Query<T>, QuerySegmentWalker) - Method in class org.apache.druid.query.spec.MultipleIntervalSegmentSpec
 
lookup(Query<T>, QuerySegmentWalker) - Method in class org.apache.druid.query.spec.MultipleSpecificSegmentSpec
 
lookup(Query<T>, QuerySegmentWalker) - Method in interface org.apache.druid.query.spec.QuerySegmentSpec
 
lookup(Query<T>, QuerySegmentWalker) - Method in class org.apache.druid.query.spec.SpecificSegmentSpec
 
LookupColumnSelectorFactory - Class in org.apache.druid.segment.join.lookup
 
LookupConfig - Class in org.apache.druid.query.lookup
 
LookupConfig(String) - Constructor for class org.apache.druid.query.lookup.LookupConfig
 
LookupDataSource - Class in org.apache.druid.query
Represents a lookup.
LookupDataSource(String) - Constructor for class org.apache.druid.query.LookupDataSource
 
LookupDimensionSpec - Class in org.apache.druid.query.dimension
 
LookupDimensionSpec(String, String, LookupExtractor, boolean, String, String, Boolean, LookupExtractorFactoryContainerProvider) - Constructor for class org.apache.druid.query.dimension.LookupDimensionSpec
 
LookupExprMacro - Class in org.apache.druid.query.expression
 
LookupExprMacro(LookupExtractorFactoryContainerProvider) - Constructor for class org.apache.druid.query.expression.LookupExprMacro
 
LookupExtractionFn - Class in org.apache.druid.query.lookup
 
LookupExtractionFn(LookupExtractor, boolean, String, Boolean, Boolean) - Constructor for class org.apache.druid.query.lookup.LookupExtractionFn
 
LookupExtractor - Class in org.apache.druid.query.lookup
 
LookupExtractor() - Constructor for class org.apache.druid.query.lookup.LookupExtractor
 
LookupExtractorFactory - Interface in org.apache.druid.query.lookup
Users of Lookup Extraction need to implement a LookupExtractorFactory supplier of type LookupExtractor.
LookupExtractorFactoryContainer - Class in org.apache.druid.query.lookup
 
LookupExtractorFactoryContainer(String, LookupExtractorFactory) - Constructor for class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
 
LookupExtractorFactoryContainerProvider - Interface in org.apache.druid.query.lookup
Provides LookupExtractorFactoryContainer to query and indexing time dimension transformations.
lookupId(ActualType) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
lookupId(String) - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
lookupId(String) - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
lookupId(String) - Method in interface org.apache.druid.segment.IdLookup
lookupId(String) - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
lookupId(String) - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
LookupIntrospectHandler - Interface in org.apache.druid.query.lookup
This interface is empty because it only exists to signal intent.
LookupJoinable - Class in org.apache.druid.segment.join.lookup
 
LookupJoinMatcher - Class in org.apache.druid.segment.join.lookup
 
lookupName(int) - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
lookupName(int) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
lookupName(int) - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
lookupName(int) - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
lookupName(int) - Method in interface org.apache.druid.segment.DimensionDictionarySelector
The Name is the String name of the actual field.
lookupName(int) - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
lookupName(int) - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
lookupName(int) - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
lookupName(int) - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
lookupName(int) - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
lookupName(int) - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
lookupName(int) - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
LookupSegment - Class in org.apache.druid.query.lookup
A Segment that is based on a LookupExtractor.
LookupSegment(String, LookupExtractorFactory) - Constructor for class org.apache.druid.query.lookup.LookupSegment
 
LookupSnapshotTaker - Class in org.apache.druid.query.lookup
 
LookupSnapshotTaker(ObjectMapper, String) - Constructor for class org.apache.druid.query.lookup.LookupSnapshotTaker
 
LookupsState<T> - Class in org.apache.druid.query.lookup
 
LookupsState(Map<String, T>, Map<String, T>, Set<String>) - Constructor for class org.apache.druid.query.lookup.LookupsState
 
LowerExtractionFn - Class in org.apache.druid.query.extraction
 
LowerExtractionFn(String) - Constructor for class org.apache.druid.query.extraction.LowerExtractionFn
 
LruEvalCache() - Constructor for class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector.LruEvalCache
 
LruEvalCache(Expr, Expr.ObjectBinding) - Constructor for class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector.LruEvalCache
 
LZ4Compressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.LZ4Compressor
 
LZ4Decompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.LZ4Decompressor
 
LZF_VERSION - Static variable in class org.apache.druid.segment.data.CompressedColumnarDoublesSuppliers
 
LZF_VERSION - Static variable in class org.apache.druid.segment.data.CompressedColumnarFloatsSupplier
 
LZF_VERSION - Static variable in class org.apache.druid.segment.data.CompressedColumnarLongsSupplier
 
LZFCompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.LZFCompressor
 
LZFDecompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.LZFDecompressor
 

M

macroTable - Variable in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
macroTable - Variable in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
macroTable - Variable in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Creates an AggregateCombiner to fold rollup aggregation results from serveral "rows" of different indexes during index merging.
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
makeAggregators(Cursor, List<AggregatorFactory>) - Static method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
makeBitmapIndexSelector(VirtualColumns) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
makeBitmapResultFactory(BitmapFactory) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
makeBitmapResultFactory(BitmapFactory) - Method in interface org.apache.druid.query.QueryMetrics
Creates a BitmapResultFactory which may record some information along bitmap construction from QueryMetrics.preFilters(List).
makeBitmapResultFactory(BitmapFactory) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
makeBufferAggregators(Cursor, List<AggregatorFactory>) - Static method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
makeBufferComparatorForDouble(int, boolean, StringComparator) - Static method in class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
 
makeBufferComparatorForFloat(int, boolean, StringComparator) - Static method in class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
 
makeBufferComparatorForLong(int, boolean, StringComparator) - Static method in class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
 
makeClosingQueryRunner(QueryRunner<T>, Closeable) - Static method in class org.apache.druid.query.QueryRunnerHelper
 
makeColumnDescriptor() - Method in interface org.apache.druid.segment.DimensionMergerV9
Return a ColumnDescriptor containing ColumnPartSerde objects appropriate for this DimensionMerger's value metadata, sequence of row values, and index structures.
makeColumnDescriptor() - Method in class org.apache.druid.segment.DoubleDimensionMergerV9
 
makeColumnDescriptor() - Method in class org.apache.druid.segment.FloatDimensionMergerV9
 
makeColumnDescriptor() - Method in class org.apache.druid.segment.LongDimensionMergerV9
 
makeColumnDescriptor() - Method in class org.apache.druid.segment.StringDimensionMergerV9
 
makeColumnSelectorFactory(VirtualColumns, AggregatorFactory, Supplier<InputRow>, boolean) - Static method in class org.apache.druid.segment.incremental.IncrementalIndex
Column selector used at ingestion time for inputs to aggregators.
makeColumnSelectorFactory(AggregatorFactory, Supplier<InputRow>, boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
makeColumnSelectorFactory(ReadableOffset, boolean, Closer) - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
makeColumnSelectorFactory(ReadableOffset, boolean, Closer) - Method in interface org.apache.druid.segment.join.table.IndexedTable
This method allows a table to directly provide an optimized ColumnSelectorFactory for IndexedTableJoinMatcher to create selectors.
makeColumnSelectorStrategy(ColumnCapabilities, ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.cardinality.types.CardinalityAggregatorColumnSelectorStrategyFactory
 
makeColumnSelectorStrategy(ColumnCapabilities, ColumnValueSelector) - Method in interface org.apache.druid.query.dimension.ColumnSelectorStrategyFactory
 
makeColumnSelectorStrategy(ColumnCapabilities, ColumnValueSelector) - Method in class org.apache.druid.query.topn.types.TopNColumnAggregatesProcessorFactory
 
makeColumnValueSelector(ReadableOffset) - Method in interface org.apache.druid.segment.column.BaseColumn
 
makeColumnValueSelector(ReadableOffset) - Method in interface org.apache.druid.segment.column.ComplexColumn
Optionally overridden when complex column serialization is not based on default serialization based on GenericIndexed in ComplexColumnSerializer.
makeColumnValueSelector(ReadableOffset) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
makeColumnValueSelector(ReadableOffset) - Method in class org.apache.druid.segment.column.DoublesColumn
 
makeColumnValueSelector(ReadableOffset) - Method in class org.apache.druid.segment.column.FloatsColumn
 
makeColumnValueSelector(ReadableOffset) - Method in class org.apache.druid.segment.column.LongsColumn
 
makeColumnValueSelector(ReadableOffset) - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
makeColumnValueSelector(String) - Method in interface org.apache.druid.segment.ColumnSelectorFactory
Returns ColumnValueSelector corresponding to the given column name, or NilColumnValueSelector if the column with such name is absent.
makeColumnValueSelector(ReadableOffset, ImmutableBitmap) - Method in interface org.apache.druid.segment.data.ColumnarDoubles
 
makeColumnValueSelector(ReadableOffset, ImmutableBitmap) - Method in interface org.apache.druid.segment.data.ColumnarFloats
 
makeColumnValueSelector(ReadableOffset, ImmutableBitmap) - Method in interface org.apache.druid.segment.data.ColumnarLongs
 
makeColumnValueSelector(IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in interface org.apache.druid.segment.DimensionIndexer
Return an object used to read values from this indexer's column.
makeColumnValueSelector(IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
makeColumnValueSelector(IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
makeColumnValueSelector(String) - Method in class org.apache.druid.segment.join.filter.AllNullColumnSelectorFactory
 
makeColumnValueSelector(String) - Method in class org.apache.druid.segment.join.lookup.LookupColumnSelectorFactory
 
makeColumnValueSelector(String) - Method in class org.apache.druid.segment.join.table.IndexedTableColumnSelectorFactory
 
makeColumnValueSelector(IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
makeColumnValueSelector(String) - Method in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
 
makeColumnValueSelector(String) - Method in class org.apache.druid.segment.RowBasedColumnSelectorFactory
 
makeColumnValueSelector(IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
makeColumnValueSelector(ColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
Makes a ColumnValueSelector whose getObject method returns an Object that is the value computed by an ExprEval.
makeColumnValueSelector(String, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
makeColumnValueSelector(String) - Method in class org.apache.druid.segment.virtual.VirtualizedColumnSelectorFactory
 
makeColumnValueSelector(String, ColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
Build a ColumnValueSelector corresponding to this virtual column.
makeColumnValueSelector(String, ColumnSelector, ReadableOffset) - Method in interface org.apache.druid.segment.VirtualColumn
Returns similar ColumnValueSelector object as returned by VirtualColumn.makeColumnValueSelector(String, ColumnSelectorFactory) except this method has full access to the underlying column and can potentially provide a more efficient implementation.
makeColumnValueSelector(String, ColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
Create a column value selector.
makeColumnValueSelector(String, ColumnSelector, ReadableOffset) - Method in class org.apache.druid.segment.VirtualColumns
Try to create an optimized value selector directly from a ColumnSelector.
makeComplexProcessor(BaseObjectColumnValueSelector<?>) - Method in interface org.apache.druid.segment.ColumnProcessorFactory
Create a processor for a complex column.
makeComplexProcessor(BaseObjectColumnValueSelector<?>) - Method in class org.apache.druid.segment.filter.ConstantValueMatcherFactory
 
makeComplexProcessor(BaseObjectColumnValueSelector<?>) - Method in class org.apache.druid.segment.filter.PredicateValueMatcherFactory
 
makeContinuousUniform(String, ValueType, boolean, int, Double, double, double) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeCursorBasedQuery(StorageAdapter, List<Interval>, Filter, VirtualColumns, boolean, Granularity, Function<Cursor, Result<T>>) - Static method in class org.apache.druid.query.QueryRunnerHelper
 
makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in interface org.apache.druid.segment.CursorFactory
Creates a sequence of Cursors, one for each time-granular bucket (based on the provided Granularity).
makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
 
makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
 
makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in class org.apache.druid.segment.RowBasedStorageAdapter
 
makeDefaultStartupModules() - Static method in class org.apache.druid.guice.GuiceInjectors
 
makeDimensionProcessor(DimensionSelector, boolean) - Method in interface org.apache.druid.segment.ColumnProcessorFactory
Create a processor for a string column.
makeDimensionProcessor(DimensionSelector, boolean) - Method in class org.apache.druid.segment.filter.ConstantValueMatcherFactory
 
makeDimensionProcessor(DimensionSelector, boolean) - Method in class org.apache.druid.segment.filter.PredicateValueMatcherFactory
 
makeDimensionSelector(ReadableOffset, ExtractionFn) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
makeDimensionSelector(ReadableOffset, ExtractionFn) - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
makeDimensionSelector(DimensionSpec) - Method in interface org.apache.druid.segment.ColumnSelectorFactory
 
makeDimensionSelector(DimensionSpec, IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in interface org.apache.druid.segment.DimensionIndexer
Return an object used to read values from this indexer's column as Strings.
makeDimensionSelector(DimensionSpec, IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
makeDimensionSelector(DimensionSpec, IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.join.filter.AllNullColumnSelectorFactory
 
makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.join.lookup.LookupColumnSelectorFactory
 
makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.join.table.IndexedTableColumnSelectorFactory
 
makeDimensionSelector(DimensionSpec, IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
 
makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.RowBasedColumnSelectorFactory
 
makeDimensionSelector(DimensionSpec, IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
makeDimensionSelector(ColumnSelectorFactory, Expr, ExtractionFn) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
Makes a single or multi-value DimensionSelector wrapper around a ColumnValueSelector created by ExpressionSelectors.makeExprEvalSelector(ColumnSelectorFactory, Expr) as appropriate
makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.virtual.VirtualizedColumnSelectorFactory
 
makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
Build a selector corresponding to this virtual column.
makeDimensionSelector(DimensionSpec, ColumnSelector, ReadableOffset) - Method in interface org.apache.druid.segment.VirtualColumn
Returns similar DimensionSelector object as returned by VirtualColumn.makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) except this method has full access to the underlying column and can potentially provide a more efficient implementation.
makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
Create a dimension (string) selector.
makeDimensionSelector(DimensionSpec, ColumnSelector, ReadableOffset) - Method in class org.apache.druid.segment.VirtualColumns
Try to create an optimized dimension (string) selector directly from a ColumnSelector.
makeDimFile(File, String) - Static method in class org.apache.druid.segment.IndexIO
 
makeDimValAggregateStore(Parameters) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
makeDimValAggregateStore(TopNParams) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
makeDimValAggregateStore(PooledTopNAlgorithm.PooledTopNParams) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
makeDimValAggregateStore(TopNParams) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
makeDimValSelector(Parameters, int, int) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
makeDimValSelector(TopNParams, int, int) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
makeDimValSelector(PooledTopNAlgorithm.PooledTopNParams, int, int) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
makeDimValSelector(TopNParams, int, int) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
makeDiscreteUniform(String, ValueType, boolean, int, Double, int, int) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeDoublePredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
 
makeDoublePredicate() - Method in class org.apache.druid.query.filter.InDimFilter.InFilterDruidPredicateFactory
 
makeDoublePredicate() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
makeDoublePredicate() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
 
makeDoubleProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.filter.vector.VectorValueMatcherColumnProcessorFactory
 
makeDoubleProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
 
makeDoubleProcessor(BaseDoubleColumnValueSelector) - Method in interface org.apache.druid.segment.ColumnProcessorFactory
Create a processor for a double column.
makeDoubleProcessor(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.segment.filter.ConstantValueMatcherFactory
 
makeDoubleProcessor(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.segment.filter.PredicateValueMatcherFactory
 
makeDoubleProcessor(ColumnCapabilities, VectorValueSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
 
makeDoubleValueMatcher(BaseDoubleColumnValueSelector, String) - Static method in class org.apache.druid.segment.filter.ValueMatchers
Creates a constant-based ValueMatcher for a double-typed selector.
makeDoubleValueMatcher(BaseDoubleColumnValueSelector, DruidPredicateFactory) - Static method in class org.apache.druid.segment.filter.ValueMatchers
Creates a predicate-based ValueMatcher for a double-typed selector.
makeEmptyImmutableBitmap() - Method in interface org.apache.druid.collections.bitmap.BitmapFactory
 
makeEmptyImmutableBitmap() - Method in class org.apache.druid.collections.bitmap.BitSetBitmapFactory
 
makeEmptyImmutableBitmap() - Method in class org.apache.druid.collections.bitmap.ConciseBitmapFactory
 
makeEmptyImmutableBitmap() - Method in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
makeEmptyMutableBitmap() - Method in interface org.apache.druid.collections.bitmap.BitmapFactory
Create a new empty bitmap
makeEmptyMutableBitmap() - Method in class org.apache.druid.collections.bitmap.BitSetBitmapFactory
 
makeEmptyMutableBitmap() - Method in class org.apache.druid.collections.bitmap.ConciseBitmapFactory
 
makeEmptyMutableBitmap() - Method in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
makeEnumerated(String, ValueType, boolean, int, Double, List<Object>, List<Double>) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeEnumeratedDiscreteUniform(String, ValueType, boolean, int, Double, List<Object>) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeEnumeratedSequential(String, ValueType, boolean, int, Double, List<Object>) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeEnumeratedZipf(String, ValueType, boolean, int, Double, List<Object>, Double) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeExprEvalSelector(ColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
Makes a ColumnValueSelector whose getObject method returns an ExprEval.
makeExprEvalSelector(ColumnSelectorFactory, ExpressionPlan) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
 
makeFactory(Properties) - Method in class org.apache.druid.guice.ConfigModule
 
makeFloatPredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
 
makeFloatPredicate() - Method in class org.apache.druid.query.filter.InDimFilter.InFilterDruidPredicateFactory
 
makeFloatPredicate() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
makeFloatPredicate() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
 
makeFloatProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.filter.vector.VectorValueMatcherColumnProcessorFactory
 
makeFloatProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
 
makeFloatProcessor(BaseFloatColumnValueSelector) - Method in interface org.apache.druid.segment.ColumnProcessorFactory
Create a processor for a float column.
makeFloatProcessor(BaseFloatColumnValueSelector) - Method in class org.apache.druid.segment.filter.ConstantValueMatcherFactory
 
makeFloatProcessor(BaseFloatColumnValueSelector) - Method in class org.apache.druid.segment.filter.PredicateValueMatcherFactory
 
makeFloatProcessor(ColumnCapabilities, VectorValueSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
 
makeFloatValueMatcher(BaseFloatColumnValueSelector, String) - Static method in class org.apache.druid.segment.filter.ValueMatchers
Creates a constant-based ValueMatcher for a float-typed selector.
makeFloatValueMatcher(BaseFloatColumnValueSelector, DruidPredicateFactory) - Static method in class org.apache.druid.segment.filter.ValueMatchers
Creates a predicate-based ValueMatcher for a float-typed selector.
makeGenerator(long) - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeGrouperIterator(Grouper<RowBasedGrouperHelper.RowBasedKey>, GroupByQuery, Closeable) - Static method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper
 
makeGrouperIterator(Grouper<RowBasedGrouperHelper.RowBasedKey>, GroupByQuery, List<String>, Closeable) - Static method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper
 
makeImmutableBitmap(MutableBitmap) - Method in interface org.apache.druid.collections.bitmap.BitmapFactory
 
makeImmutableBitmap(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.BitSetBitmapFactory
 
makeImmutableBitmap(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.ConciseBitmapFactory
 
makeImmutableBitmap(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
makeIncrementalIndex(GroupByQuery, GroupByQuery, GroupByQueryConfig, NonBlockingPool<ByteBuffer>, Sequence<ResultRow>) - Static method in class org.apache.druid.query.groupby.GroupByQueryHelper
 
makeIndexer() - Method in interface org.apache.druid.segment.DimensionHandler
Creates a new DimensionIndexer, a per-dimension object responsible for processing ingested rows in-memory, used by the IncrementalIndex.
makeIndexer() - Method in class org.apache.druid.segment.DoubleDimensionHandler
 
makeIndexer() - Method in class org.apache.druid.segment.FloatDimensionHandler
 
makeIndexer() - Method in class org.apache.druid.segment.LongDimensionHandler
 
makeIndexer() - Method in class org.apache.druid.segment.StringDimensionHandler
 
makeInitParams(ColumnSelectorPlus, Cursor) - Method in class org.apache.druid.query.topn.AggregateTopNMetricFirstAlgorithm
 
makeInitParams(ColumnSelectorPlus<TopNColumnAggregatesProcessor>, Cursor) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
makeInitParams(ColumnSelectorPlus, Cursor) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
makeInitParams(ColumnSelectorPlus, Cursor) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
makeInitParams(ColumnSelectorPlus<TopNColumnAggregatesProcessor>, Cursor) - Method in interface org.apache.druid.query.topn.TopNAlgorithm
 
makeJoinCursor(Cursor, JoinableClause, boolean, Closer) - Static method in class org.apache.druid.segment.join.HashJoinEngine
Creates a cursor that represents the join of with .
makeJoinMatcher(ColumnSelectorFactory, JoinConditionAnalysis, boolean, boolean, Closer) - Method in interface org.apache.druid.segment.join.Joinable
Creates a JoinMatcher that can be used to implement a join onto this Joinable.
makeJoinMatcher(ColumnSelectorFactory, JoinConditionAnalysis, boolean, boolean, Closer) - Method in class org.apache.druid.segment.join.lookup.LookupJoinable
 
makeJoinMatcher(ColumnSelectorFactory, JoinConditionAnalysis, boolean, boolean, Closer) - Method in class org.apache.druid.segment.join.table.IndexedTableJoinable
 
makeLazyDiscreteUniform(String, ValueType, boolean, int, Double, int, int) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeLazyZipf(String, ValueType, boolean, int, Double, int, int, Double) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeLongPredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
 
makeLongPredicate() - Method in class org.apache.druid.query.filter.InDimFilter.InFilterDruidPredicateFactory
 
makeLongPredicate() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
makeLongPredicate() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
 
makeLongProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.filter.vector.VectorValueMatcherColumnProcessorFactory
 
makeLongProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
 
makeLongProcessor(BaseLongColumnValueSelector) - Method in interface org.apache.druid.segment.ColumnProcessorFactory
Create a processor for a long column.
makeLongProcessor(BaseLongColumnValueSelector) - Method in class org.apache.druid.segment.filter.ConstantValueMatcherFactory
 
makeLongProcessor(BaseLongColumnValueSelector) - Method in class org.apache.druid.segment.filter.PredicateValueMatcherFactory
 
makeLongProcessor(ColumnCapabilities, VectorValueSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
 
makeLongValueMatcher(BaseLongColumnValueSelector, String) - Static method in class org.apache.druid.segment.filter.ValueMatchers
 
makeLongValueMatcher(BaseLongColumnValueSelector, DruidPredicateFactory) - Static method in class org.apache.druid.segment.filter.ValueMatchers
 
makeMatcher(BitmapIndexSelector, ColumnSelectorFactory, RowOffsetMatcherFactory) - Method in interface org.apache.druid.query.filter.BooleanFilter
Get a ValueMatcher that applies this filter to row values.
makeMatcher(ColumnSelectorFactory) - Method in interface org.apache.druid.query.filter.Filter
Get a ValueMatcher that applies this filter to row values.
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.query.filter.InDimFilter
 
makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.DoubleVectorValueMatcher
 
makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.DoubleVectorValueMatcher
 
makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.FloatVectorValueMatcher
 
makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.FloatVectorValueMatcher
 
makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.LongVectorValueMatcher
 
makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.LongVectorValueMatcher
 
makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.MultiValueStringVectorValueMatcher
 
makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.MultiValueStringVectorValueMatcher
 
makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.SingleValueStringVectorValueMatcher
 
makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.SingleValueStringVectorValueMatcher
 
makeMatcher(String) - Method in interface org.apache.druid.query.filter.vector.VectorValueMatcherFactory
 
makeMatcher(DruidPredicateFactory) - Method in interface org.apache.druid.query.filter.vector.VectorValueMatcherFactory
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.AndFilter
 
makeMatcher(BitmapIndexSelector, ColumnSelectorFactory, RowOffsetMatcherFactory) - Method in class org.apache.druid.segment.filter.AndFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.BoundFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.FalseFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.LikeFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.NotFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.OrFilter
 
makeMatcher(BitmapIndexSelector, ColumnSelectorFactory, RowOffsetMatcherFactory) - Method in class org.apache.druid.segment.filter.OrFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.SpatialFilter
 
makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.TrueFilter
 
makeMerger(IndexSpec, SegmentWriteOutMedium, ColumnCapabilities, ProgressIndicator, Closer) - Method in interface org.apache.druid.segment.DimensionHandler
Creates a new DimensionMergerV9, a per-dimension object responsible for merging indexes/row data across segments and building the on-disk representation of a dimension.
makeMerger(IndexSpec, SegmentWriteOutMedium, ColumnCapabilities, ProgressIndicator, Closer) - Method in class org.apache.druid.segment.DoubleDimensionHandler
 
makeMerger(IndexSpec, SegmentWriteOutMedium, ColumnCapabilities, ProgressIndicator, Closer) - Method in class org.apache.druid.segment.FloatDimensionHandler
 
makeMerger(IndexSpec, SegmentWriteOutMedium, ColumnCapabilities, ProgressIndicator, Closer) - Method in class org.apache.druid.segment.LongDimensionHandler
 
makeMerger(IndexSpec, SegmentWriteOutMedium, ColumnCapabilities, ProgressIndicator, Closer) - Method in class org.apache.druid.segment.StringDimensionHandler
 
makeMetricColumnValueSelector(String, IncrementalIndexRowHolder) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
makeMetricFile(File, String, ByteOrder) - Static method in class org.apache.druid.segment.IndexIO
 
makeMetrics(DataSourceMetadataQuery) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
 
makeMetrics(Query<?>) - Method in class org.apache.druid.query.DefaultGenericQueryMetricsFactory
 
makeMetrics(Query<?>) - Method in interface org.apache.druid.query.GenericQueryMetricsFactory
Creates a QueryMetrics for query, which doesn't have predefined QueryMetrics subclass.
makeMetrics() - Method in class org.apache.druid.query.groupby.DefaultGroupByQueryMetricsFactory
 
makeMetrics() - Method in interface org.apache.druid.query.groupby.GroupByQueryMetricsFactory
 
makeMetrics(GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
makeMetrics(SegmentMetadataQuery) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
makeMetrics(QueryType) - Method in class org.apache.druid.query.QueryToolChest
Creates a QueryMetrics object that is used to generate metrics for this specific query type.
makeMetrics(ScanQuery) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
 
makeMetrics(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetricsFactory
 
makeMetrics(SearchQuery) - Method in interface org.apache.druid.query.search.SearchQueryMetricsFactory
 
makeMetrics(SearchQuery) - Method in class org.apache.druid.query.search.SearchQueryQueryToolChest
 
makeMetrics(TimeBoundaryQuery) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
makeMetrics() - Method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetricsFactory
 
makeMetrics() - Method in interface org.apache.druid.query.timeseries.TimeseriesQueryMetricsFactory
 
makeMetrics(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
makeMetrics() - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetricsFactory
 
makeMetrics() - Method in interface org.apache.druid.query.topn.TopNQueryMetricsFactory
 
makeMetrics(TopNQuery) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
makeMultiValueDimensionProcessor(ColumnCapabilities, MultiValueDimensionVectorSelector) - Method in class org.apache.druid.query.filter.vector.VectorValueMatcherColumnProcessorFactory
 
makeMultiValueDimensionProcessor(ColumnCapabilities, MultiValueDimensionVectorSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
 
makeMultiValueDimensionProcessor(ColumnCapabilities, MultiValueDimensionVectorSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
 
makeMultiValueDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
 
makeMultiValueDimensionSelector(DimensionSpec) - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
Returns a string-typed, multi-value-per-row column selector.
makeMultiValueDimensionVectorSelector(ReadableVectorOffset) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
makeMultiValueDimensionVectorSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
makeMultiValueDimensionVectorSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
Create a multi value dimension vector (string) selector.
makeMultiValueDimensionVectorSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) - Method in class org.apache.druid.segment.VirtualColumns
Try to create an optimized multi value dimension (string) vector selector, directly from a ColumnSelector.
makeMultiValueVectorDimensionSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
Build a MultiValueDimensionVectorSelector corresponding to this virtual column.
makeMultiValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) - Method in interface org.apache.druid.segment.VirtualColumn
Returns similar SingleValueDimensionVectorSelector object as returned by VirtualColumn.makeSingleValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) except this method has full access to the underlying column and can potentially provide a more efficient implementation.
makeNewSettableColumnValueSelector() - Method in interface org.apache.druid.segment.column.ColumnHolder
Returns a new instance of a SettableColumnValueSelector, corresponding to the type of this column.
makeNewSettableColumnValueSelector(ValueType) - Static method in class org.apache.druid.segment.column.ValueTypes
 
makeNewSettableEncodedValueSelector() - Method in interface org.apache.druid.segment.DimensionHandler
Creates and returns a new object of some implementation of SettableColumnValueSelector, that corresponds to the type of this DimensionHandler.
makeNewSettableEncodedValueSelector() - Method in class org.apache.druid.segment.DoubleDimensionHandler
 
makeNewSettableEncodedValueSelector() - Method in class org.apache.druid.segment.FloatDimensionHandler
 
makeNewSettableEncodedValueSelector() - Method in class org.apache.druid.segment.LongDimensionHandler
 
makeNewSettableEncodedValueSelector() - Method in class org.apache.druid.segment.StringDimensionHandler
 
makeNormal(String, ValueType, boolean, int, Double, Double, Double, boolean) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeNullableAggregateCombiner() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Creates an AggregateCombiner which supports nullability.
makeNullableAggregateCombiner() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
 
makeNullHandlingBufferComparatorForNumericData(int, Grouper.BufferComparator) - Static method in class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
 
makeNullValueMatcher(VectorValueSelector) - Method in interface org.apache.druid.query.filter.vector.VectorValueMatcherFactory
 
makeNumericWrappingDimensionSelector(ValueType, ColumnValueSelector<?>, ExtractionFn) - Static method in class org.apache.druid.segment.column.ValueTypes
 
makeObjectSelector(String) - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
 
makeObjectSelector(String) - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
Returns an object selector, useful for complex columns.
makePostComputeManipulatorFn(GroupByQuery, MetricManipulationFn) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
makePostComputeManipulatorFn(QueryType, MetricManipulationFn) - Method in class org.apache.druid.query.QueryToolChest
Generally speaking this is the exact same thing as makePreComputeManipulatorFn.
makePostComputeManipulatorFn(TimeseriesQuery, MetricManipulationFn) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
makePostComputeManipulatorFn(TopNQuery, MetricManipulationFn) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
makePreComputeManipulatorFn(DataSourceMetadataQuery, MetricManipulationFn) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
 
makePreComputeManipulatorFn(GroupByQuery, MetricManipulationFn) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
makePreComputeManipulatorFn(SegmentMetadataQuery, MetricManipulationFn) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
makePreComputeManipulatorFn(QueryType, MetricManipulationFn) - Method in class org.apache.druid.query.QueryToolChest
Creates a Function that can take in a ResultType and return a new ResultType having applied the MetricManipulatorFn to each of the metrics.
makePreComputeManipulatorFn(ScanQuery, MetricManipulationFn) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
 
makePreComputeManipulatorFn(SearchQuery, MetricManipulationFn) - Method in class org.apache.druid.query.search.SearchQueryQueryToolChest
 
makePreComputeManipulatorFn(TimeBoundaryQuery, MetricManipulationFn) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
makePreComputeManipulatorFn(TimeseriesQuery, MetricManipulationFn) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
makePreComputeManipulatorFn(TopNQuery, MetricManipulationFn) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
makePredicateMatchingSet(DimensionSelector, Predicate<String>) - Static method in class org.apache.druid.segment.DimensionSelectorUtils
 
makeProcessor(String, ColumnProcessorFactory<T>, ColumnSelectorFactory) - Static method in class org.apache.druid.segment.ColumnProcessors
Make a processor for a particular named column.
makeProcessor(DimensionSpec, ColumnProcessorFactory<T>, ColumnSelectorFactory) - Static method in class org.apache.druid.segment.ColumnProcessors
Make a processor for a particular DimensionSpec.
makeProcessor(Expr, ValueType, ColumnProcessorFactory<T>, ColumnSelectorFactory) - Static method in class org.apache.druid.segment.ColumnProcessors
Make a processor for a particular expression.
makeRequestMetrics(GenericQueryMetricsFactory, QueryToolChest<T, Query<T>>, Query<T>, String) - Static method in class org.apache.druid.query.DruidMetrics
 
makeResultBuilder(TopNParams, TopNQuery) - Static method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
makeRowIteratorWithConvertedDimensionColumns(TransformableRowIterator, ColumnValueSelector[], ColumnValueSelector[]) - Static method in interface org.apache.druid.segment.IndexMerger
 
makeRowOffsetMatcher(ImmutableBitmap) - Method in interface org.apache.druid.query.filter.RowOffsetMatcherFactory
 
makeSegmentWriteOutMedium(File) - Method in class org.apache.druid.segment.writeout.OffHeapMemorySegmentWriteOutMediumFactory
 
makeSegmentWriteOutMedium(File) - Method in class org.apache.druid.segment.writeout.OnHeapMemorySegmentWriteOutMediumFactory
 
makeSegmentWriteOutMedium(File) - Method in interface org.apache.druid.segment.writeout.SegmentWriteOutMediumFactory
Creates a new SegmentWriteOutMedium.
makeSegmentWriteOutMedium(File) - Method in class org.apache.druid.segment.writeout.TmpFileSegmentWriteOutMediumFactory
 
makeSequential(String, ValueType, boolean, int, Double, int, int) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
makeSingleValueDimensionProcessor(ColumnCapabilities, SingleValueDimensionVectorSelector) - Method in class org.apache.druid.query.filter.vector.VectorValueMatcherColumnProcessorFactory
 
makeSingleValueDimensionProcessor(ColumnCapabilities, SingleValueDimensionVectorSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
 
makeSingleValueDimensionProcessor(ColumnCapabilities, SingleValueDimensionVectorSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
 
makeSingleValueDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
 
makeSingleValueDimensionSelector(DimensionSpec) - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
Returns a string-typed, single-value-per-row column selector.
makeSingleValueDimensionVectorSelector(ReadableVectorOffset) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
 
makeSingleValueDimensionVectorSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
makeSingleValueDimensionVectorSelector(VectorColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionVectorSelectors
 
makeSingleValueDimensionVectorSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
Create a single value dimension vector (string) selector.
makeSingleValueDimensionVectorSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) - Method in class org.apache.druid.segment.VirtualColumns
Try to create an optimized single value dimension (string) vector selector, directly from a ColumnSelector.
makeSingleValueVectorDimensionSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
makeSingleValueVectorDimensionSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
Build a SingleValueDimensionVectorSelector corresponding to this virtual column.
makeSingleValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) - Method in interface org.apache.druid.segment.VirtualColumn
Returns similar SingleValueDimensionVectorSelector object as returned by VirtualColumn.makeSingleValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) except this method has full access to the underlying column and can potentially provide a more efficient implementation.
makeStartupInjector() - Static method in class org.apache.druid.guice.GuiceInjectors
 
makeStartupInjectorWithModules(Iterable<? extends Module>) - Static method in class org.apache.druid.guice.GuiceInjectors
 
makeStringPredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
 
makeStringPredicate() - Method in class org.apache.druid.query.filter.InDimFilter.InFilterDruidPredicateFactory
 
makeStringPredicate() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter.JavaScriptPredicateFactory
 
makeStringPredicate() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
 
makeStringValueMatcher(DimensionSelector, String, boolean) - Static method in class org.apache.druid.segment.filter.ValueMatchers
Creates a constant-based ValueMatcher for a string-typed selector.
makeStringValueMatcher(DimensionSelector, DruidPredicateFactory, boolean) - Static method in class org.apache.druid.segment.filter.ValueMatchers
Creates a predicate-based ValueMatcher for a string-typed selector.
makeTimeFile(File, ByteOrder) - Static method in class org.apache.druid.segment.IndexIO
 
makeValueMatcher(String) - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
makeValueMatcher(Predicate<String>) - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
makeValueMatcher(String) - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
makeValueMatcher(Predicate<String>) - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
makeValueMatcher(String) - Method in interface org.apache.druid.segment.DimensionSelector
 
makeValueMatcher(Predicate<String>) - Method in interface org.apache.druid.segment.DimensionSelector
 
makeValueMatcher(List<Supplier<String[]>>) - Static method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
makeValueMatcher(ColumnSelectorFactory, String, String) - Static method in class org.apache.druid.segment.filter.Filters
Create a ValueMatcher that compares row values to the provided string.
makeValueMatcher(ColumnSelectorFactory, String, DruidPredicateFactory) - Static method in class org.apache.druid.segment.filter.Filters
Create a ValueMatcher that applies a predicate to row values.
makeValueMatcher(String) - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
makeValueMatcher(Predicate<String>) - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
makeValueMatcher(String) - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
makeValueMatcher(Predicate<String>) - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
makeValueMatcher(String) - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
makeValueMatcher(Predicate<String>) - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
makeValueMatcher(String) - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
makeValueMatcher(Predicate<String>) - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
makeValueMatcher(String) - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
makeValueMatcher(Predicate<String>) - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
makeValueMatcher(String) - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
makeValueMatcher(Predicate<String>) - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
makeValueMatcherGeneric(DimensionSelector, String) - Static method in class org.apache.druid.segment.DimensionSelectorUtils
makeValueMatcherGeneric(DimensionSelector, Predicate<String>) - Static method in class org.apache.druid.segment.DimensionSelectorUtils
makeValueSelector(String) - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
 
makeValueSelector(String) - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
Returns a primitive column selector.
makeVectorCursor(Filter, Interval, VirtualColumns, boolean, int, QueryMetrics<?>) - Method in interface org.apache.druid.segment.CursorFactory
Creates a VectorCursor.
makeVectorCursor(Filter, Interval, VirtualColumns, boolean, int, QueryMetrics<?>) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in interface org.apache.druid.query.filter.Filter
Get a VectorValueMatcher that applies this filter to row vectors.
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.filter.InDimFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.AndFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.BoundFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.FalseFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.LikeFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.NotFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.OrFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.TrueFilter
 
makeVectorObjectSelector(ReadableVectorOffset) - Method in interface org.apache.druid.segment.column.BaseColumn
 
makeVectorObjectSelector(ReadableVectorOffset) - Method in interface org.apache.druid.segment.column.ComplexColumn
 
makeVectorObjectSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
makeVectorObjectSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
makeVectorObjectSelector(VectorColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionVectorSelectors
 
makeVectorObjectSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
makeVectorObjectSelector(String, VectorColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
Build a VectorObjectSelector corresponding to this virtual column.
makeVectorObjectSelector(String, ColumnSelector, ReadableVectorOffset) - Method in interface org.apache.druid.segment.VirtualColumn
Returns similar VectorObjectSelector object as returned by VirtualColumn.makeVectorObjectSelector(String, VectorColumnSelectorFactory) except this method has full access to the underlying column and can potentially provide a more efficient implementation.
makeVectorObjectSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
Create a column vector object selector.
makeVectorObjectSelector(String, ColumnSelector, ReadableVectorOffset) - Method in class org.apache.druid.segment.VirtualColumns
Try to create an optimized vector object selector directly from a ColumnSelector.If this method returns null, callers should try to fallback to VirtualColumns.makeVectorObjectSelector(String, VectorColumnSelectorFactory) instead.
makeVectorProcessor(String, VectorColumnProcessorFactory<T>, VectorColumnSelectorFactory) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
Equivalent to calling makeVectorProcessor(DefaultDimensionSpec.of(column), strategyFactory, selectorFactory).
makeVectorProcessor(DimensionSpec, VectorColumnProcessorFactory<T>, VectorColumnSelectorFactory) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
Creates "vector processors", which are objects that wrap a single vectorized input column and provide some functionality on top of it.
makeVectorValueSelector(VectorColumnSelectorFactory, String, String, Supplier<Expr>) - Static method in class org.apache.druid.query.aggregation.AggregatorUtil
Make a VectorValueSelector for primitive numeric or expression virtual column inputs.
makeVectorValueSelector(ReadableVectorOffset) - Method in interface org.apache.druid.segment.column.BaseColumn
 
makeVectorValueSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.DoublesColumn
 
makeVectorValueSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.FloatsColumn
 
makeVectorValueSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.LongsColumn
 
makeVectorValueSelector(ReadableVectorOffset, ImmutableBitmap) - Method in interface org.apache.druid.segment.data.ColumnarDoubles
 
makeVectorValueSelector(ReadableVectorOffset, ImmutableBitmap) - Method in interface org.apache.druid.segment.data.ColumnarFloats
 
makeVectorValueSelector(ReadableVectorOffset, ImmutableBitmap) - Method in interface org.apache.druid.segment.data.ColumnarLongs
 
makeVectorValueSelector(VectorColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionVectorSelectors
 
makeVectorValueSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
makeVectorValueSelector(String, VectorColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
Build a VectorValueSelector corresponding to this virtual column.
makeVectorValueSelector(String, ColumnSelector, ReadableVectorOffset) - Method in interface org.apache.druid.segment.VirtualColumn
Returns similar VectorValueSelector object as returned by VirtualColumn.makeVectorValueSelector(String, VectorColumnSelectorFactory) except this method has full access to the underlying column and can potentially provide a more efficient implementation.
makeVectorValueSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
Create a column vector value selector.
makeVectorValueSelector(String, ColumnSelector, ReadableVectorOffset) - Method in class org.apache.druid.segment.VirtualColumns
Try to create an optimized vector value selector directly from a ColumnSelector.
makeWriteOutBytes() - Method in class org.apache.druid.segment.writeout.OffHeapMemorySegmentWriteOutMedium
 
makeWriteOutBytes() - Method in class org.apache.druid.segment.writeout.OnHeapMemorySegmentWriteOutMedium
 
makeWriteOutBytes() - Method in interface org.apache.druid.segment.writeout.SegmentWriteOutMedium
Creates a new empty WriteOutBytes, attached to this SegmentWriteOutMedium.
makeWriteOutBytes() - Method in class org.apache.druid.segment.writeout.TmpFileSegmentWriteOutMedium
 
makeZipf(String, ValueType, boolean, int, Double, int, int, Double) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
manipulate(AggregatorFactory, Object) - Method in interface org.apache.druid.query.aggregation.MetricManipulationFn
 
map(Function<QueryRunner<T>, QueryRunner<T>>) - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
map(Function<? super T, ? extends U>) - Method in class org.apache.druid.query.Result
 
mapDir(File) - Method in class org.apache.druid.segment.IndexIO.DefaultIndexIOHandler
 
mapImmutableBitmap(ByteBuffer) - Method in interface org.apache.druid.collections.bitmap.BitmapFactory
Given a ByteBuffer pointing at a serialized version of a bitmap, instantiate an immutable mapped bitmap.
mapImmutableBitmap(ByteBuffer) - Method in class org.apache.druid.collections.bitmap.BitSetBitmapFactory
 
mapImmutableBitmap(ByteBuffer) - Method in class org.apache.druid.collections.bitmap.ConciseBitmapFactory
 
mapImmutableBitmap(ByteBuffer) - Method in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
MapJoinableFactory - Class in org.apache.druid.segment.join
A JoinableFactory that delegates to the appropriate factory based on the datasource.
MapJoinableFactory(Set<JoinableFactory>, Map<Class<? extends JoinableFactory>, Class<? extends DataSource>>) - Constructor for class org.apache.druid.segment.join.MapJoinableFactory
 
MapLookupExtractor - Class in org.apache.druid.query.extraction
 
MapLookupExtractor(Map<String, String>, boolean) - Constructor for class org.apache.druid.query.extraction.MapLookupExtractor
 
MapQueryToolChestWarehouse - Class in org.apache.druid.query
 
MapQueryToolChestWarehouse(Map<Class<? extends Query>, QueryToolChest>) - Constructor for class org.apache.druid.query.MapQueryToolChestWarehouse
 
mapResults(Function<? super T, ? extends U>) - Method in class org.apache.druid.query.BySegmentResultValueClass
 
mark() - Method in class org.apache.druid.segment.ForwardingRowIterator
 
mark() - Method in interface org.apache.druid.segment.RowIterator
"Memoizes" the data point, to which RowIterator.getPointer() currently points.
match(ReadableVectorMatch) - Method in class org.apache.druid.query.filter.vector.BooleanVectorValueMatcher
 
match(ReadableVectorMatch) - Method in class org.apache.druid.query.filter.vector.FalseVectorMatcher
 
match(ReadableVectorMatch) - Method in class org.apache.druid.query.filter.vector.TrueVectorMatcher
 
match(ReadableVectorMatch) - Method in interface org.apache.druid.query.filter.vector.VectorValueMatcher
Examine the current vector and return a match indicating what is accepted.
MATCH_NULL_ONLY - Static variable in interface org.apache.druid.query.filter.DruidDoublePredicate
 
MATCH_NULL_ONLY - Static variable in interface org.apache.druid.query.filter.DruidFloatPredicate
 
MATCH_NULL_ONLY - Static variable in interface org.apache.druid.query.filter.DruidLongPredicate
 
matchCondition() - Method in interface org.apache.druid.segment.join.JoinMatcher
matchCondition() - Method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
 
matchCondition() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinMatcher
 
matches(String) - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
 
matches() - Method in interface org.apache.druid.query.filter.ValueMatcher
 
matchesSuffixOnly(Indexed<String>, int) - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
Checks if the suffix of strings.get(i) matches the suffix of this matcher.
MatchingDimExtractionFn - Class in org.apache.druid.query.extraction
 
MatchingDimExtractionFn(String) - Constructor for class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
matchingRemainder() - Method in interface org.apache.druid.segment.join.JoinMatcher
Returns whether this matcher is currently matching the remainder (i.e.
matchingRemainder() - Method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
 
matchingRemainder() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinMatcher
 
matchPredicate(String, BitmapIndexSelector, BitmapResultFactory<T>, Predicate<String>) - Static method in class org.apache.druid.segment.filter.Filters
Return the union of bitmaps for all values matching a particular predicate.
matchPredicateNoUnion(String, BitmapIndexSelector, Predicate<String>) - Static method in class org.apache.druid.segment.filter.Filters
Return an iterable of bitmaps for all values matching a particular predicate.
matchRemainder() - Method in interface org.apache.druid.segment.join.JoinMatcher
Matches every row that has not already been matched.
matchRemainder() - Method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
 
matchRemainder() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinMatcher
 
max - Variable in class org.apache.druid.query.aggregation.Histogram
 
MAX_DEFAULT_PROCESSING_BUFFER_SIZE_BYTES - Static variable in class org.apache.druid.query.DruidProcessingConfig
 
MAX_INTERMEDIATE_SIZE - Static variable in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
MAX_INTS_IN_BUFFER - Static variable in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
 
MAX_QUEUED_BYTES_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
MAX_SCATTER_GATHER_BYTES_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
MAX_SUBQUERY_ROWS_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
MAX_TABLE_SIZE - Static variable in class org.apache.druid.segment.data.CompressionFactory
 
MAX_TIME - Static variable in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
maxBuckets - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
maxBytesInMemory - Variable in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
maxIntsInBufferForBytes(int) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
maxIntsInBufferForValue(int) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
maxLoadFactor - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
 
maxLoadFactor - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
maxRowCount - Variable in class org.apache.druid.segment.incremental.OffheapIncrementalIndex
 
maxRowCount - Variable in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
 
maxSize() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage
 
maxSizeForBuckets(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
maxSizeForTesting - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
maxStringBytes - Variable in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
maxStringBytes - Variable in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
maxStringBytes - Variable in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
maybeWriteByte(Predicate<T>, MetaSerdeHelper.ByteFieldWriter<T>) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
 
mean() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
MEAN_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
memory() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the memory backing this table.
memoryEquals(Memory, long, Memory, long, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.collection.HashTableUtils
Compare two memory ranges for equality.
memoryNeeded(int, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the amount of memory needed for a table.
MemoryOpenHashTable - Class in org.apache.druid.query.groupby.epinephelinae.collection
An open-addressed hash table with linear probing backed by WritableMemory.
MemoryOpenHashTable(WritableMemory, int, int, int, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Create a new table.
MemoryOpenHashTable.BucketCopyHandler - Interface in org.apache.druid.query.groupby.epinephelinae.collection
merge(ResponseContext) - Method in class org.apache.druid.query.context.ResponseContext
Merges a response context into the current.
merge(boolean) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
merge(LimitSpec) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
merge(LimitSpec) - Method in interface org.apache.druid.query.groupby.orderby.LimitSpec
 
merge(LimitSpec) - Method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
merge(ColumnCapabilities, ColumnCapabilities, ColumnCapabilities.CoercionLogic) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
Snapshots a pair of capabilities and then merges them
merge(List<IndexableAdapter>, boolean, AggregatorFactory[], File, IndexSpec) - Method in interface org.apache.druid.segment.IndexMerger
 
merge(List<IndexableAdapter>, boolean, AggregatorFactory[], File, IndexSpec) - Method in class org.apache.druid.segment.IndexMergerV9
 
merge(List<Metadata>, AggregatorFactory[]) - Static method in class org.apache.druid.segment.Metadata
 
mergeAggregators(List<AggregatorFactory[]>) - Static method in class org.apache.druid.query.aggregation.AggregatorFactory
Merges the list of AggregatorFactory[] (presumable from metadata of some segments being merged) and returns merged AggregatorFactory[] (for the metadata for merged segment).
mergeAnalyses(SegmentAnalysis, SegmentAnalysis, boolean) - Static method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
mergeAndGetDictionary() - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
Returns a dictionary of string keys added to this grouper.
mergeAscending(List<IntIterator>) - Static method in class org.apache.druid.segment.IntIteratorUtils
Merges several iterators of ascending int values into a single iterator of ascending int values.
mergeIndexed(List<Iterable<T>>) - Static method in interface org.apache.druid.segment.IndexMerger
 
mergeQueryableIndex(List<QueryableIndex>, boolean, AggregatorFactory[], File, IndexSpec, SegmentWriteOutMediumFactory) - Method in interface org.apache.druid.segment.IndexMerger
 
mergeQueryableIndex(List<QueryableIndex>, boolean, AggregatorFactory[], File, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory) - Method in interface org.apache.druid.segment.IndexMerger
 
mergeQueryableIndex(List<QueryableIndex>, boolean, AggregatorFactory[], File, IndexSpec, SegmentWriteOutMediumFactory) - Method in class org.apache.druid.segment.IndexMergerV9
 
mergeQueryableIndex(List<QueryableIndex>, boolean, AggregatorFactory[], File, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory) - Method in class org.apache.druid.segment.IndexMergerV9
 
mergeResults(List<Result<DataSourceMetadataResultValue>>) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
mergeResults(QueryRunner<Result<DataSourceMetadataResultValue>>) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
 
mergeResults() - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
mergeResults(QueryRunner<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
mergeResults(QueryRunner<ResultRow>, GroupByQuery, ResponseContext) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Runs a provided QueryRunner on a provided GroupByQuery, which is assumed to return rows that are properly sorted (by timestamp and dimensions) but not necessarily fully merged (that is, there may be adjacent rows with the same timestamp and dimensions) and without PostAggregators computed.
mergeResults(QueryRunner<ResultRow>, GroupByQuery, ResponseContext) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
mergeResults(QueryRunner<ResultRow>, GroupByQuery, ResponseContext) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
mergeResults(QueryRunner<SegmentAnalysis>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
mergeResults(QueryRunner<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
This method wraps a QueryRunner.
mergeResults(QueryRunner<ScanResultValue>) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
 
mergeResults(List<Result<TimeBoundaryResultValue>>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
mergeResults(QueryRunner<Result<TimeBoundaryResultValue>>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
mergeResults(QueryRunner<Result<TimeseriesResultValue>>) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
mergeRunners(ExecutorService, Iterable<QueryRunner<Result<DataSourceMetadataResultValue>>>) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQueryRunnerFactory
 
mergeRunners(ExecutorService, Iterable<QueryRunner<ResultRow>>) - Method in class org.apache.druid.query.groupby.GroupByQueryRunnerFactory
 
mergeRunners(ListeningExecutorService, Iterable<QueryRunner<ResultRow>>) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Merge a variety of single-segment query runners into a combined runner.
mergeRunners(ListeningExecutorService, Iterable<QueryRunner<ResultRow>>) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
mergeRunners(ListeningExecutorService, Iterable<QueryRunner<ResultRow>>) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
mergeRunners(ExecutorService, Iterable<QueryRunner<SegmentAnalysis>>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryRunnerFactory
 
mergeRunners(ExecutorService, Iterable<QueryRunner<T>>) - Method in interface org.apache.druid.query.QueryRunnerFactory
Runners generated with createRunner() and combined into an Iterable in (time,shardId) order are passed along to this method with an ExecutorService.
mergeRunners(ExecutorService, Iterable<QueryRunner<ScanResultValue>>) - Method in class org.apache.druid.query.scan.ScanQueryRunnerFactory
 
mergeRunners(ExecutorService, Iterable<QueryRunner<Result<SearchResultValue>>>) - Method in class org.apache.druid.query.search.SearchQueryRunnerFactory
 
mergeRunners(ExecutorService, Iterable<QueryRunner<Result<TimeBoundaryResultValue>>>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryRunnerFactory
 
mergeRunners(ExecutorService, Iterable<QueryRunner<Result<TimeseriesResultValue>>>) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryRunnerFactory
 
mergeRunners(ExecutorService, Iterable<QueryRunner<Result<TopNResultValue>>>) - Method in class org.apache.druid.query.topn.TopNQueryRunnerFactory
 
Merging - Annotation Type in org.apache.druid.guice.annotations
 
Metadata - Class in org.apache.druid.segment
 
Metadata(Map<String, Object>, AggregatorFactory[], TimestampSpec, Granularity, Boolean) - Constructor for class org.apache.druid.segment.Metadata
 
MetaSerdeHelper<T> - Class in org.apache.druid.segment.serde
 
MetaSerdeHelper.ByteFieldWriter<T> - Interface in org.apache.druid.segment.serde
 
MetaSerdeHelper.FieldWriter<T> - Interface in org.apache.druid.segment.serde
 
MetaSerdeHelper.IntFieldWriter<T> - Interface in org.apache.druid.segment.serde
 
metaSize() - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
 
metaSize() - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
metaSize() - Method in class org.apache.druid.segment.data.LongsLongEncodingWriter
 
metaSize() - Method in class org.apache.druid.segment.data.TableLongEncodingWriter
 
metric(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
metric(TopNMetricSpec) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
METRIC_CAPABILITY_MERGE_LOGIC - Static variable in class org.apache.druid.segment.IndexMergerV9
 
MetricDesc(int, AggregatorFactory) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndex.MetricDesc
 
MetricHolder - Class in org.apache.druid.segment
 
MetricHolder.MetricType - Enum in org.apache.druid.segment
 
MetricManipulationFn - Interface in org.apache.druid.query.aggregation
 
MetricManipulatorFns - Class in org.apache.druid.query.aggregation
 
MetricManipulatorFns() - Constructor for class org.apache.druid.query.aggregation.MetricManipulatorFns
 
metrics - Variable in class org.apache.druid.query.DefaultQueryMetrics
 
MetricsEmittingExecutorService - Class in org.apache.druid.query
 
MetricsEmittingExecutorService(ListeningExecutorService, ExecutorServiceMonitor) - Constructor for class org.apache.druid.query.MetricsEmittingExecutorService
 
MetricsEmittingQueryRunner<T> - Class in org.apache.druid.query
 
MetricsEmittingQueryRunner(ServiceEmitter, QueryToolChest<T, ? extends Query<T>>, QueryRunner<T>, ObjLongConsumer<? super QueryMetrics<?>>, Consumer<QueryMetrics<?>>) - Constructor for class org.apache.druid.query.MetricsEmittingQueryRunner
 
MetricValueExtractor - Class in org.apache.druid.query
 
MetricValueExtractor(Map<String, Object>) - Constructor for class org.apache.druid.query.MetricValueExtractor
 
min - Variable in class org.apache.druid.query.aggregation.Histogram
 
MIN_TIME - Static variable in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
MMappedIndex - Class in org.apache.druid.segment
 
MMappedIndex(GenericIndexed<String>, GenericIndexed<String>, Interval, CompressedColumnarLongsSupplier, Map<String, MetricHolder>, Map<String, GenericIndexed<String>>, Map<String, VSizeColumnarMultiInts>, Map<String, GenericIndexed<ImmutableBitmap>>, Map<String, ImmutableRTree>, SmooshedFileMapper) - Constructor for class org.apache.druid.segment.MMappedIndex
 
MMappedQueryableSegmentizerFactory - Class in org.apache.druid.segment.loading
 
MMappedQueryableSegmentizerFactory(IndexIO) - Constructor for class org.apache.druid.segment.loading.MMappedQueryableSegmentizerFactory
 
ModulesConfig - Class in org.apache.druid.guice
 
ModulesConfig() - Constructor for class org.apache.druid.guice.ModulesConfig
 
MOMENTS_SKETCH_BUILD_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
MOMENTS_SKETCH_MERGE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
MOMENTS_SKETCH_TO_MAX_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
MOMENTS_SKETCH_TO_MIN_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
MOMENTS_SKETCH_TO_QUANTILES_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
moveToNext() - Method in class org.apache.druid.segment.ForwardingRowIterator
 
moveToNext() - Method in interface org.apache.druid.segment.TimeAndDimsIterator
Moves iterator to the next data point.
MultipleIntervalSegmentSpec - Class in org.apache.druid.query.spec
 
MultipleIntervalSegmentSpec(List<Interval>) - Constructor for class org.apache.druid.query.spec.MultipleIntervalSegmentSpec
 
MultipleSpecificSegmentSpec - Class in org.apache.druid.query.spec
 
MultipleSpecificSegmentSpec(List<SegmentDescriptor>) - Constructor for class org.apache.druid.query.spec.MultipleSpecificSegmentSpec
 
multipleValues() - Method in interface org.apache.druid.segment.column.ColumnCapabilities.CoercionLogic
If ColumnCapabilities.hasMultipleValues() is ColumnCapabilities.Capable.UNKNOWN, define if it should be treated as true or false.
MultiValueDimensionVectorSelector - Interface in org.apache.druid.segment.vector
Vectorized selector for a multi-valued string-typed column.
MultiValueStringVectorValueMatcher - Class in org.apache.druid.query.filter.vector
 
MultiValueStringVectorValueMatcher(MultiValueDimensionVectorSelector) - Constructor for class org.apache.druid.query.filter.vector.MultiValueStringVectorValueMatcher
 
mustDecorate() - Method in class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
mustDecorate() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
mustDecorate() - Method in interface org.apache.druid.query.dimension.DimensionSpec
Does this DimensionSpec require that decorate() be called to produce correct results?
mustDecorate() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
mustDecorate() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
MutableBitmap - Interface in org.apache.druid.collections.bitmap
This class is meant to represent a simple wrapper around a bitmap class.

N

name - Variable in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
name - Variable in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
name - Variable in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
name() - Method in class org.apache.druid.query.expression.CaseInsensitiveContainsExprMacro
 
name() - Method in class org.apache.druid.query.expression.ContainsExprMacro
 
name() - Method in class org.apache.druid.query.expression.IPv4AddressMatchExprMacro
 
name() - Method in class org.apache.druid.query.expression.IPv4AddressParseExprMacro
 
name() - Method in class org.apache.druid.query.expression.IPv4AddressStringifyExprMacro
 
name() - Method in class org.apache.druid.query.expression.LikeExprMacro
 
name() - Method in class org.apache.druid.query.expression.LookupExprMacro
 
name() - Method in class org.apache.druid.query.expression.RegexpExtractExprMacro
 
name() - Method in class org.apache.druid.query.expression.RegexpLikeExprMacro
 
name() - Method in class org.apache.druid.query.expression.TimestampCeilExprMacro
 
name() - Method in class org.apache.druid.query.expression.TimestampExtractExprMacro
 
name() - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro
 
name() - Method in class org.apache.druid.query.expression.TimestampFormatExprMacro
 
name() - Method in class org.apache.druid.query.expression.TimestampParseExprMacro
 
name() - Method in class org.apache.druid.query.expression.TimestampShiftExprMacro
 
name() - Method in class org.apache.druid.query.expression.TrimExprMacro
 
NAME - Static variable in class org.apache.druid.query.search.AutoStrategy
 
NAME - Static variable in class org.apache.druid.query.search.CursorOnlyStrategy
 
NAME - Static variable in class org.apache.druid.query.search.UseIndexesStrategy
 
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
 
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.ConstantDimensionSelector
 
nameLookupPossibleInAdvance() - Method in interface org.apache.druid.segment.DimensionDictionarySelector
Returns true if it is possible to DimensionDictionarySelector.lookupName(int) by ids from 0 to DimensionDictionarySelector.getValueCardinality() before the rows with those ids are returned.
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
 
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.vector.NilVectorSelector
 
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
 
nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
needToSplit(Node) - Method in class org.apache.druid.collections.spatial.split.GutmanSplitStrategy
 
needToSplit(Node) - Method in interface org.apache.druid.collections.spatial.split.SplitStrategy
 
NeverHavingSpec - Class in org.apache.druid.query.groupby.having
A "having" spec that always evaluates to false
NeverHavingSpec() - Constructor for class org.apache.druid.query.groupby.having.NeverHavingSpec
 
newBucketHook(int) - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
Called when a new bucket is used for an entry in the hash table.
newBucketHook(int) - Method in class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
newBucketHook(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
newDataSourceMetadataQueryBuilder() - Static method in class org.apache.druid.query.Druids
 
newImmutableFromMutable(RTree) - Static method in class org.apache.druid.collections.spatial.ImmutableRTree
 
newScanQueryBuilder() - Static method in class org.apache.druid.query.Druids
 
newSearchQueryBuilder() - Static method in class org.apache.druid.query.Druids
 
newSegmentMetadataQueryBuilder() - Static method in class org.apache.druid.query.Druids
 
newTaskFor(Runnable, T) - Method in class org.apache.druid.query.PrioritizedExecutorService
 
newTaskFor(Callable<T>) - Method in class org.apache.druid.query.PrioritizedExecutorService
 
newTimeBoundaryQueryBuilder() - Static method in class org.apache.druid.query.Druids
 
newTimeseriesQueryBuilder() - Static method in class org.apache.druid.query.Druids
 
next() - Method in class org.apache.druid.collections.bitmap.PeekableIteratorAdapter
 
next() - Method in class org.apache.druid.collections.IntegerSet.BitSetIterator
 
next() - Method in class org.apache.druid.query.groupby.epinephelinae.CloseableGrouperIterator
 
next() - Method in class org.apache.druid.query.scan.ScanQueryLimitRowIterator
 
next() - Method in class org.apache.druid.segment.IndexMerger.DictionaryMergeIterator
 
nextBatch(int[]) - Method in class org.apache.druid.collections.bitmap.BatchIteratorAdapter
 
nextInt() - Method in class org.apache.druid.segment.join.table.SortedIntIntersectionIterator
 
nextMatch() - Method in interface org.apache.druid.segment.join.JoinMatcher
Moves on to the next match.
nextMatch() - Method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
 
nextMatch() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinMatcher
 
nextRow() - Method in class org.apache.druid.segment.generator.DataGenerator
 
nilBindings() - Static method in class org.apache.druid.query.expression.ExprUtils
 
NilColumnValueSelector - Class in org.apache.druid.segment
Represents "absent" column.
NilVectorSelector - Class in org.apache.druid.segment.vector
 
NO_TIMEOUT - Static variable in class org.apache.druid.query.QueryContexts
 
Node - Class in org.apache.druid.collections.spatial
 
Node(float[], float[], boolean, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.Node
 
Node(float[], float[], Node, boolean, Node, MutableBitmap) - Constructor for class org.apache.druid.collections.spatial.Node
This constructor accepts a single nullable child Node (null value means no child) instead of a collection of children Nodes, because Nodes with no more than one child are created in the codebase yet, while passing a collection of Nodes would necessitate making a defensive copy of this collection in the constructor and extra overhead.
NoFilterVectorOffset - Class in org.apache.druid.segment.vector
 
NoFilterVectorOffset(int, int, int) - Constructor for class org.apache.druid.segment.vector.NoFilterVectorOffset
 
NONE - Static variable in class org.apache.druid.segment.transform.TransformSpec
 
NoneColumnIncluderator - Class in org.apache.druid.query.metadata.metadata
 
NoneColumnIncluderator() - Constructor for class org.apache.druid.query.metadata.metadata.NoneColumnIncluderator
 
noNoneValues() - Static method in enum org.apache.druid.segment.data.CompressionStrategy
 
NoopAggregator - Class in org.apache.druid.query.aggregation
 
NoopBufferAggregator - Class in org.apache.druid.query.aggregation
 
NoopLimitSpec - Class in org.apache.druid.query.groupby.orderby
 
NoopQueryRunner<T> - Class in org.apache.druid.query
 
NoopQueryRunner() - Constructor for class org.apache.druid.query.NoopQueryRunner
 
NoopRowIngestionMeters - Class in org.apache.druid.segment.incremental
This class is used only in RealtimeIndexTask which is deprecated now.
NoopRowIngestionMeters() - Constructor for class org.apache.druid.segment.incremental.NoopRowIngestionMeters
 
NoopVectorAggregator - Class in org.apache.druid.query.aggregation
 
not(DimFilter) - Static method in class org.apache.druid.query.filter.DimFilters
 
NOT_EXIST - Static variable in interface org.apache.druid.segment.IndexMerger.IndexSeeker
 
NOT_EXIST - Static variable in interface org.apache.druid.segment.StringDimensionMergerV9.IndexSeeker
 
NOT_INIT - Static variable in interface org.apache.druid.segment.IndexMerger.IndexSeeker
 
NOT_INIT - Static variable in interface org.apache.druid.segment.StringDimensionMergerV9.IndexSeeker
 
NotDimFilter - Class in org.apache.druid.query.filter
 
NotDimFilter(DimFilter) - Constructor for class org.apache.druid.query.filter.NotDimFilter
 
NotFilter - Class in org.apache.druid.segment.filter
 
NotFilter(Filter) - Constructor for class org.apache.druid.segment.filter.NotFilter
 
NotHavingSpec - Class in org.apache.druid.query.groupby.having
The logical "not" operator for the "having" clause.
NotHavingSpec(HavingSpec) - Constructor for class org.apache.druid.query.groupby.having.NotHavingSpec
 
NULL_ID - Static variable in interface org.apache.druid.segment.vector.ReadableVectorOffset
A marker value that will never be returned by "getId".
NullableDoubleGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
NullableFloatGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
NullableLongGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
NullableNumericAggregateCombiner<T> - Class in org.apache.druid.query.aggregation
Null-aware numeric AggregateCombiner.
NullableNumericAggregateCombiner(AggregateCombiner<T>) - Constructor for class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
NullableNumericAggregator - Class in org.apache.druid.query.aggregation
Null-aware numeric Aggregator.
NullableNumericAggregator(Aggregator, BaseNullableColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.NullableNumericAggregator
 
NullableNumericAggregatorFactory<T extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.aggregation
Abstract superclass for null-aware numeric aggregators.
NullableNumericAggregatorFactory() - Constructor for class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
 
NullableNumericBufferAggregator - Class in org.apache.druid.query.aggregation
Null-aware numeric BufferAggregator.
NullableNumericBufferAggregator(BufferAggregator, BaseNullableColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
NullableNumericGroupByColumnSelectorStrategy - Class in org.apache.druid.query.groupby.epinephelinae.column
A wrapper around a numeric GroupByColumnSelectorStrategy that makes it null-aware.
NullableNumericGroupByColumnSelectorStrategy(GroupByColumnSelectorStrategy) - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
NullableNumericTopNColumnAggregatesProcessor<Selector extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.topn.types
NullableNumericTopNColumnAggregatesProcessor(Function<Object, Comparable<?>>) - Constructor for class org.apache.druid.query.topn.types.NullableNumericTopNColumnAggregatesProcessor
 
NullableNumericVectorAggregator - Class in org.apache.druid.query.aggregation
A wrapper around a non-null-aware VectorAggregator that makes it null-aware.
NullDimensionSelectorHolder() - Constructor for class org.apache.druid.segment.DimensionSelector.NullDimensionSelectorHolder
 
NullHandlingModule - Class in org.apache.druid.guice
 
NullHandlingModule() - Constructor for class org.apache.druid.guice.NullHandlingModule
 
nullToEmpty(VirtualColumns) - Static method in class org.apache.druid.segment.VirtualColumns
 
nullToNoopLimitSpec(LimitSpec) - Static method in interface org.apache.druid.query.groupby.orderby.LimitSpec
 
nullToZero(Double) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
nullToZero(Long) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
nullToZero(Float) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
 
nullValue() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
nullValue() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
NUM_RETRIES_ON_MISSING_SEGMENTS_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
numBuckets() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the number of buckets in this table.
numComplexMetrics(GroupByQuery) - Method in class org.apache.druid.query.groupby.DefaultGroupByQueryMetrics
 
numComplexMetrics(GroupByQuery) - Method in interface org.apache.druid.query.groupby.GroupByQueryMetrics
Sets the number of "complex" metrics of the given groupBy query as dimension.
numComplexMetrics(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetrics
 
numComplexMetrics(TimeseriesQuery) - Method in interface org.apache.druid.query.timeseries.TimeseriesQueryMetrics
Sets the number of "complex" metrics of the given timeseries query as dimension.
numComplexMetrics(TopNQuery) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
numComplexMetrics(TopNQuery) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
Sets the number of "complex" metrics of the given topN query as dimension.
numDimensions(GroupByQuery) - Method in class org.apache.druid.query.groupby.DefaultGroupByQueryMetrics
 
numDimensions(GroupByQuery) - Method in interface org.apache.druid.query.groupby.GroupByQueryMetrics
Sets the size of GroupByQuery.getDimensions() of the given query as dimension.
NUMERIC - Static variable in class org.apache.druid.query.ordering.StringComparators
 
NUMERIC_CACHE_ID - Static variable in class org.apache.druid.query.ordering.StringComparators
 
NUMERIC_NAME - Static variable in class org.apache.druid.query.ordering.StringComparators
 
NumericAnyAggregator<TSelector extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.aggregation.any
Base type for on heap 'any' aggregator for primitive numeric column selectors
NumericAnyAggregator(TSelector) - Constructor for class org.apache.druid.query.aggregation.any.NumericAnyAggregator
 
NumericAnyBufferAggregator<TSelector extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.aggregation.any
Base type for buffer based 'any' aggregator for primitive numeric column selectors
NumericAnyBufferAggregator(TSelector) - Constructor for class org.apache.druid.query.aggregation.any.NumericAnyBufferAggregator
 
NumericAnyVectorAggregator - Class in org.apache.druid.query.aggregation.any
 
NumericAnyVectorAggregator(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.any.NumericAnyVectorAggregator
 
NumericColumn - Interface in org.apache.druid.segment.column
 
NumericComparator() - Constructor for class org.apache.druid.query.ordering.StringComparators.NumericComparator
 
NumericDimensionMergerV9 - Class in org.apache.druid.segment
NumericFirstAggregator<TSelector extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.aggregation.first
Base type for on heap 'first' aggregator for primitive numeric column selectors
NumericFirstAggregator(BaseLongColumnValueSelector, TSelector) - Constructor for class org.apache.druid.query.aggregation.first.NumericFirstAggregator
 
NumericFirstBufferAggregator<TSelector extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.aggregation.first
Base type for buffer based 'first' aggregator for primitive numeric column selectors
NumericFirstBufferAggregator(BaseLongColumnValueSelector, TSelector) - Constructor for class org.apache.druid.query.aggregation.first.NumericFirstBufferAggregator
 
NumericLastAggregator<TSelector extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.aggregation.last
Base type for on heap 'last' aggregator for primitive numeric column selectors..
NumericLastAggregator(BaseLongColumnValueSelector, TSelector) - Constructor for class org.apache.druid.query.aggregation.last.NumericLastAggregator
 
NumericLastBufferAggregator<TSelector extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.aggregation.last
Base type for buffer based 'last' aggregator for primitive numeric column selectors This could probably share a base type with NumericFirstBufferAggregator ...
NumericLastBufferAggregator(BaseLongColumnValueSelector, TSelector) - Constructor for class org.apache.druid.query.aggregation.last.NumericLastBufferAggregator
 
NumericNilVectorAggregator - Class in org.apache.druid.query.aggregation.any
A vector aggregator that returns the default numeric value.
NumericTopNMetricSpec - Class in org.apache.druid.query.topn
 
NumericTopNMetricSpec(String) - Constructor for class org.apache.druid.query.topn.NumericTopNMetricSpec
 
numMetrics(GroupByQuery) - Method in class org.apache.druid.query.groupby.DefaultGroupByQueryMetrics
 
numMetrics(GroupByQuery) - Method in interface org.apache.druid.query.groupby.GroupByQueryMetrics
Sets the number of metrics of the given groupBy query as dimension.
numMetrics(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetrics
 
numMetrics(TimeseriesQuery) - Method in interface org.apache.druid.query.timeseries.TimeseriesQueryMetrics
Sets the number of metrics of the given timeseries query as dimension.
numMetrics(TopNQuery) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
numMetrics(TopNQuery) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
Sets the number of metrics of the given topN query as dimension.
numRows(Segment) - Method in class org.apache.druid.query.metadata.SegmentAnalyzer
 
numRows() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
numRows() - Method in interface org.apache.druid.segment.join.table.IndexedTable
Returns the number of rows in this table.
numRows() - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
 
numRows() - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
numValuesPerPass(TopNParams) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
numValuesPerPass(TopNParams) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
This method may set TopNParams.getNumValuesPerPass() of the query as dimension.

O

ObjectAggregateCombiner<T> - Class in org.apache.druid.query.aggregation
Specialization of AggregateCombiner for object aggregations.
ObjectAggregateCombiner() - Constructor for class org.apache.druid.query.aggregation.ObjectAggregateCombiner
 
ObjectColumnSelector<T> - Class in org.apache.druid.segment
This class is convenient for implementation of "object-sourcing" ColumnValueSelectors, it provides default implementations for all ColumnValueSelector's methods except BaseObjectColumnValueSelector.getObject() and BaseObjectColumnValueSelector.classOfObject().
ObjectColumnSelector() - Constructor for class org.apache.druid.segment.ObjectColumnSelector
 
objectComparator(boolean) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerdeFactory
Return an object that knows how to compare two serialized key instances.
ObjectStrategy<T> - Interface in org.apache.druid.segment.data
 
of(String) - Static method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
of(VectorSizeInspector, boolean) - Static method in class org.apache.druid.query.filter.vector.BooleanVectorValueMatcher
 
of(Object...) - Static method in class org.apache.druid.query.groupby.ResultRow
Create a row from an array of objects.
of(HotLoopCallee) - Static method in class org.apache.druid.query.monomorphicprocessing.StringRuntimeShape
 
of(HotLoopCallee...) - Static method in class org.apache.druid.query.monomorphicprocessing.StringRuntimeShape
 
of(SearchQuery) - Static method in class org.apache.druid.query.search.AutoStrategy
 
of(SearchQuery) - Static method in class org.apache.druid.query.search.CursorOnlyStrategy
 
of(SearchQuery) - Static method in class org.apache.druid.query.search.UseIndexesStrategy
 
of(ImmutableBitmap, boolean, long) - Static method in class org.apache.druid.segment.BitmapOffset
 
of(boolean) - Static method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
of(boolean) - Static method in class org.apache.druid.segment.filter.BooleanValueMatcher
 
offer(float) - Method in class org.apache.druid.query.aggregation.Histogram
 
OffheapIncrementalIndex - Class in org.apache.druid.segment.incremental
 
OffHeapMemorySegmentWriteOutMedium - Class in org.apache.druid.segment.writeout
 
OffHeapMemorySegmentWriteOutMedium() - Constructor for class org.apache.druid.segment.writeout.OffHeapMemorySegmentWriteOutMedium
 
OffHeapMemorySegmentWriteOutMediumFactory - Class in org.apache.druid.segment.writeout
 
offset(long) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
offset(int) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.Builder
 
Offset - Class in org.apache.druid.segment.data
The "mutable" version of a ReadableOffset.
Offset() - Constructor for class org.apache.druid.segment.data.Offset
 
offset - Variable in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
 
offset - Variable in class org.apache.druid.segment.vector.BaseDoubleVectorValueSelector
 
offset - Variable in class org.apache.druid.segment.vector.BaseFloatVectorValueSelector
 
offset - Variable in class org.apache.druid.segment.vector.BaseLongVectorValueSelector
 
ofNullable(Boolean) - Static method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
ok() - Static method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
 
OnheapIncrementalIndex - Class in org.apache.druid.segment.incremental
 
OnHeapMemorySegmentWriteOutMedium - Class in org.apache.druid.segment.writeout
 
OnHeapMemorySegmentWriteOutMedium() - Constructor for class org.apache.druid.segment.writeout.OnHeapMemorySegmentWriteOutMedium
 
OnHeapMemorySegmentWriteOutMediumFactory - Class in org.apache.druid.segment.writeout
 
open() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarDoublesSerializer
 
open() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarFloatsSerializer
 
open() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarLongsSerializer
 
open() - Method in class org.apache.druid.segment.data.ByteBufferWriter
 
open() - Method in interface org.apache.druid.segment.data.ColumnarDoublesSerializer
 
open() - Method in interface org.apache.druid.segment.data.ColumnarFloatsSerializer
 
open() - Method in interface org.apache.druid.segment.data.ColumnarIntsSerializer
 
open() - Method in interface org.apache.druid.segment.data.ColumnarLongsSerializer
 
open() - Method in class org.apache.druid.segment.data.CompressedColumnarIntsSerializer
 
open() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSerializer
 
open() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSerializer
 
open() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarFloatsSerializer
 
open() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarLongsSerializer
 
open() - Method in class org.apache.druid.segment.data.GenericIndexedWriter
 
open() - Method in class org.apache.druid.segment.data.IntermediateColumnarLongsSerializer
 
open() - Method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSerializer
 
open() - Method in class org.apache.druid.segment.data.VSizeColumnarIntsSerializer
 
open() - Method in class org.apache.druid.segment.data.VSizeColumnarMultiIntsSerializer
 
open() - Method in class org.apache.druid.segment.DoubleColumnSerializer
 
open() - Method in class org.apache.druid.segment.DoubleColumnSerializerV2
 
open() - Method in class org.apache.druid.segment.FloatColumnSerializer
 
open() - Method in class org.apache.druid.segment.FloatColumnSerializerV2
 
open() - Method in interface org.apache.druid.segment.GenericColumnSerializer
 
open() - Method in class org.apache.druid.segment.LongColumnSerializer
 
open() - Method in class org.apache.druid.segment.LongColumnSerializerV2
 
open() - Method in class org.apache.druid.segment.serde.ComplexColumnSerializer
 
open() - Method in class org.apache.druid.segment.serde.LargeColumnSupportedComplexColumnSerializer
 
optimize() - Method in class org.apache.druid.query.filter.AndDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
optimize() - Method in interface org.apache.druid.query.filter.DimFilter
 
optimize(List<DimFilter>) - Static method in class org.apache.druid.query.filter.DimFilters
 
optimize() - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
optimize() - Method in class org.apache.druid.query.filter.FalseDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.InDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.NotDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.OrDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
optimize() - Method in class org.apache.druid.query.filter.TrueDimFilter
 
optimizeForSegment(PerSegmentQueryOptimizationContext) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Return a potentially optimized form of this AggregatorFactory for per-segment queries.
optimizeForSegment(PerSegmentQueryOptimizationContext) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
optimizeForSegment(PerSegmentQueryOptimizationContext) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
optimizeForSegment(PerSegmentQueryOptimizationContext) - Method in interface org.apache.druid.query.Query
 
optimizeForSegment(PerSegmentQueryOptimizationContext) - Method in class org.apache.druid.query.QueryPlus
 
optimizeForSegment(PerSegmentQueryOptimizationContext) - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
optimizeForSegment(PerSegmentQueryOptimizationContext) - Method in class org.apache.druid.query.topn.TopNQuery
 
or(MutableBitmap) - Method in interface org.apache.druid.collections.bitmap.MutableBitmap
Compute the bitwise-or of this bitmap with another bitmap.
or(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
or(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
or(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
or(DimFilter...) - Static method in class org.apache.druid.query.filter.DimFilters
 
or(List<DimFilter>) - Static method in class org.apache.druid.query.filter.DimFilters
 
or(ColumnCapabilities.Capable) - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
or(Set<Filter>) - Static method in class org.apache.druid.segment.filter.Filters
Create a filter representing an OR relationship across a set of filters.
order(ScanQuery.Order) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
orderBy(String...) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.Builder
 
orderBy(OrderByColumnSpec...) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.Builder
 
OrderByColumnSpec - Class in org.apache.druid.query.groupby.orderby
 
OrderByColumnSpec(String, OrderByColumnSpec.Direction, StringComparator) - Constructor for class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
OrderByColumnSpec(String, OrderByColumnSpec.Direction) - Constructor for class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
OrderByColumnSpec.Direction - Enum in org.apache.druid.query.groupby.orderby
 
OrDimFilter - Class in org.apache.druid.query.filter
 
OrDimFilter(List<DimFilter>) - Constructor for class org.apache.druid.query.filter.OrDimFilter
 
OrDimFilter(DimFilter...) - Constructor for class org.apache.druid.query.filter.OrDimFilter
 
OrDimFilter(String, String, String...) - Constructor for class org.apache.druid.query.filter.OrDimFilter
 
OrFilter - Class in org.apache.druid.segment.filter
 
OrFilter(List<Filter>) - Constructor for class org.apache.druid.segment.filter.OrFilter
 
OrFilter(Set<Filter>) - Constructor for class org.apache.druid.segment.filter.OrFilter
 
org.apache.druid.collections - package org.apache.druid.collections
 
org.apache.druid.collections.bitmap - package org.apache.druid.collections.bitmap
 
org.apache.druid.collections.spatial - package org.apache.druid.collections.spatial
 
org.apache.druid.collections.spatial.search - package org.apache.druid.collections.spatial.search
 
org.apache.druid.collections.spatial.split - package org.apache.druid.collections.spatial.split
 
org.apache.druid.guice - package org.apache.druid.guice
 
org.apache.druid.guice.annotations - package org.apache.druid.guice.annotations
 
org.apache.druid.jackson - package org.apache.druid.jackson
 
org.apache.druid.query - package org.apache.druid.query
 
org.apache.druid.query.aggregation - package org.apache.druid.query.aggregation
 
org.apache.druid.query.aggregation.any - package org.apache.druid.query.aggregation.any
 
org.apache.druid.query.aggregation.cardinality - package org.apache.druid.query.aggregation.cardinality
 
org.apache.druid.query.aggregation.cardinality.types - package org.apache.druid.query.aggregation.cardinality.types
 
org.apache.druid.query.aggregation.first - package org.apache.druid.query.aggregation.first
 
org.apache.druid.query.aggregation.hyperloglog - package org.apache.druid.query.aggregation.hyperloglog
 
org.apache.druid.query.aggregation.last - package org.apache.druid.query.aggregation.last
 
org.apache.druid.query.aggregation.mean - package org.apache.druid.query.aggregation.mean
 
org.apache.druid.query.aggregation.post - package org.apache.druid.query.aggregation.post
 
org.apache.druid.query.cache - package org.apache.druid.query.cache
 
org.apache.druid.query.context - package org.apache.druid.query.context
 
org.apache.druid.query.datasourcemetadata - package org.apache.druid.query.datasourcemetadata
 
org.apache.druid.query.dimension - package org.apache.druid.query.dimension
 
org.apache.druid.query.expression - package org.apache.druid.query.expression
 
org.apache.druid.query.extraction - package org.apache.druid.query.extraction
 
org.apache.druid.query.filter - package org.apache.druid.query.filter
 
org.apache.druid.query.filter.vector - package org.apache.druid.query.filter.vector
 
org.apache.druid.query.groupby - package org.apache.druid.query.groupby
 
org.apache.druid.query.groupby.epinephelinae - package org.apache.druid.query.groupby.epinephelinae
 
org.apache.druid.query.groupby.epinephelinae.collection - package org.apache.druid.query.groupby.epinephelinae.collection
 
org.apache.druid.query.groupby.epinephelinae.column - package org.apache.druid.query.groupby.epinephelinae.column
 
org.apache.druid.query.groupby.epinephelinae.vector - package org.apache.druid.query.groupby.epinephelinae.vector
 
org.apache.druid.query.groupby.having - package org.apache.druid.query.groupby.having
 
org.apache.druid.query.groupby.orderby - package org.apache.druid.query.groupby.orderby
 
org.apache.druid.query.groupby.resource - package org.apache.druid.query.groupby.resource
 
org.apache.druid.query.groupby.strategy - package org.apache.druid.query.groupby.strategy
 
org.apache.druid.query.lookup - package org.apache.druid.query.lookup
 
org.apache.druid.query.metadata - package org.apache.druid.query.metadata
 
org.apache.druid.query.metadata.metadata - package org.apache.druid.query.metadata.metadata
 
org.apache.druid.query.monomorphicprocessing - package org.apache.druid.query.monomorphicprocessing
 
org.apache.druid.query.ordering - package org.apache.druid.query.ordering
 
org.apache.druid.query.planning - package org.apache.druid.query.planning
 
org.apache.druid.query.scan - package org.apache.druid.query.scan
 
org.apache.druid.query.search - package org.apache.druid.query.search
 
org.apache.druid.query.select - package org.apache.druid.query.select
 
org.apache.druid.query.spec - package org.apache.druid.query.spec
 
org.apache.druid.query.timeboundary - package org.apache.druid.query.timeboundary
 
org.apache.druid.query.timeseries - package org.apache.druid.query.timeseries
 
org.apache.druid.query.topn - package org.apache.druid.query.topn
 
org.apache.druid.query.topn.types - package org.apache.druid.query.topn.types
 
org.apache.druid.query.vector - package org.apache.druid.query.vector
 
org.apache.druid.segment - package org.apache.druid.segment
 
org.apache.druid.segment.column - package org.apache.druid.segment.column
 
org.apache.druid.segment.data - package org.apache.druid.segment.data
 
org.apache.druid.segment.filter - package org.apache.druid.segment.filter
 
org.apache.druid.segment.filter.cnf - package org.apache.druid.segment.filter.cnf
 
org.apache.druid.segment.generator - package org.apache.druid.segment.generator
 
org.apache.druid.segment.historical - package org.apache.druid.segment.historical
 
org.apache.druid.segment.incremental - package org.apache.druid.segment.incremental
 
org.apache.druid.segment.join - package org.apache.druid.segment.join
 
org.apache.druid.segment.join.filter - package org.apache.druid.segment.join.filter
 
org.apache.druid.segment.join.filter.rewrite - package org.apache.druid.segment.join.filter.rewrite
 
org.apache.druid.segment.join.lookup - package org.apache.druid.segment.join.lookup
 
org.apache.druid.segment.join.table - package org.apache.druid.segment.join.table
 
org.apache.druid.segment.loading - package org.apache.druid.segment.loading
 
org.apache.druid.segment.selector.settable - package org.apache.druid.segment.selector.settable
 
org.apache.druid.segment.serde - package org.apache.druid.segment.serde
 
org.apache.druid.segment.transform - package org.apache.druid.segment.transform
 
org.apache.druid.segment.vector - package org.apache.druid.segment.vector
 
org.apache.druid.segment.virtual - package org.apache.druid.segment.virtual
 
org.apache.druid.segment.writeout - package org.apache.druid.segment.writeout
 
OrHavingSpec - Class in org.apache.druid.query.groupby.having
The logical "or" operator for the "having" clause.
OrHavingSpec(List<HavingSpec>) - Constructor for class org.apache.druid.query.groupby.having.OrHavingSpec
 
overlap(String[], String[]) - Static method in class org.apache.druid.segment.filter.ColumnComparisonFilter
overlap returns true when: as and bs have one or more elements in common, as and bs are both null, or as and bs are both empty.
overlaps(ImmutableNode) - Method in interface org.apache.druid.collections.spatial.search.Bound
 
overlaps(ImmutableNode) - Method in class org.apache.druid.collections.spatial.search.RectangularBound
 
overrideContext(Map<String, Object>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
overshadows(ReferenceCountingSegment) - Method in class org.apache.druid.segment.ReferenceCountingSegment
 
ownerThread - Variable in class org.apache.druid.query.DefaultQueryMetrics
Non final to give subclasses ability to reassign it.

P

ParallelCombiner<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
ParallelCombiner builds a combining tree which asynchronously aggregates input entries.
ParallelCombiner(ReferenceCountingResourceHolder<ByteBuffer>, AggregatorFactory[], Grouper.KeySerdeFactory<KeyType>, ListeningExecutorService, boolean, int, int, long, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.ParallelCombiner
 
parallelMergeParallelism(int) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
parallelMergeParallelism(int) - Method in interface org.apache.druid.query.QueryMetrics
Sets broker merge parallelism, if parallel merges are enabled.
parallelMergeParallelism(int) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
parse(String) - Method in class org.apache.druid.segment.transform.TransformingStringInputRowParser
 
parseBatch(T) - Method in class org.apache.druid.segment.transform.TransformingInputRowParser
 
parseBatch(ByteBuffer) - Method in class org.apache.druid.segment.transform.TransformingStringInputRowParser
 
ParseExceptionHandler - Class in org.apache.druid.segment.incremental
A handler for ParseExceptions thrown during ingestion.
ParseExceptionHandler(RowIngestionMeters, boolean, int, int) - Constructor for class org.apache.druid.segment.incremental.ParseExceptionHandler
 
partial(int, String) - Static method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
 
peekableIterator() - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
 
peekableIterator() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
peekableIterator() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
peekableIterator() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
peekableIterator() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
PeekableIteratorAdapter<TIntIterator extends org.roaringbitmap.IntIterator> - Class in org.apache.druid.collections.bitmap
 
peekNext() - Method in class org.apache.druid.collections.bitmap.PeekableIteratorAdapter
 
PerSegmentOptimizingQueryRunner<T> - Class in org.apache.druid.query
This runner optimizes queries made on a single segment, using per-segment information, before submitting the queries to the base runner.
PerSegmentOptimizingQueryRunner(QueryRunner<T>, PerSegmentQueryOptimizationContext) - Constructor for class org.apache.druid.query.PerSegmentOptimizingQueryRunner
 
PerSegmentQueryOptimizationContext - Class in org.apache.druid.query
Holds information about a single segment that Query objects can use to optimize themselves when they are run on that single segment.
PerSegmentQueryOptimizationContext(SegmentDescriptor) - Constructor for class org.apache.druid.query.PerSegmentQueryOptimizationContext
 
persist(IncrementalIndex, File, IndexSpec, SegmentWriteOutMediumFactory) - Method in interface org.apache.druid.segment.IndexMerger
 
persist(IncrementalIndex, Interval, File, IndexSpec, SegmentWriteOutMediumFactory) - Method in interface org.apache.druid.segment.IndexMerger
This is *not* thread-safe and havok will ensue if this is called and writes are still occurring on the IncrementalIndex object.
persist(IncrementalIndex, Interval, File, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory) - Method in interface org.apache.druid.segment.IndexMerger
 
persist(IncrementalIndex, File, IndexSpec, SegmentWriteOutMediumFactory) - Method in class org.apache.druid.segment.IndexMergerV9
 
persist(IncrementalIndex, Interval, File, IndexSpec, SegmentWriteOutMediumFactory) - Method in class org.apache.druid.segment.IndexMergerV9
 
persist(IncrementalIndex, Interval, File, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory) - Method in class org.apache.druid.segment.IndexMergerV9
 
pickNext(List<Node>) - Method in class org.apache.druid.collections.spatial.split.GutmanSplitStrategy
 
pickNext(List<Node>) - Method in class org.apache.druid.collections.spatial.split.LinearGutmanSplitStrategy
This algorithm is from the original paper.
pickSeeds(List<Node>) - Method in class org.apache.druid.collections.spatial.split.GutmanSplitStrategy
 
pickSeeds(List<Node>) - Method in class org.apache.druid.collections.spatial.split.LinearGutmanSplitStrategy
This algorithm is from the original paper.
plan(ColumnInspector, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionPlanner
Druid tries to be chill to expressions to make up for not having a well defined table schema across segments.
Point - Class in org.apache.druid.collections.spatial
 
Point(float[], int, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.Point
 
Point(float[], MutableBitmap) - Constructor for class org.apache.druid.collections.spatial.Point
 
PolygonBound - Class in org.apache.druid.collections.spatial.search
 
poolCacheMaxCount() - Method in class org.apache.druid.query.DruidProcessingConfig
 
PooledTopNAlgorithm - Class in org.apache.druid.query.topn
This TopNAlgorithm is highly specialized for processing aggregates on string columns that are ColumnCapabilities.isDictionaryEncoded() and ColumnCapabilities.areDictionaryValuesUnique().
PooledTopNAlgorithm(StorageAdapter, TopNQuery, NonBlockingPool<ByteBuffer>) - Constructor for class org.apache.druid.query.topn.PooledTopNAlgorithm
 
PooledTopNAlgorithm.PooledTopNParams - Class in org.apache.druid.query.topn
 
PooledTopNAlgorithm.PooledTopNParams.Builder - Class in org.apache.druid.query.topn
 
PooledTopNParams(ColumnSelectorPlus, Cursor, ResourceHolder<ByteBuffer>, ByteBuffer, int[], int, int, TopNMetricSpecBuilder<int[]>) - Constructor for class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
 
populateNullVector(boolean[], ReadableVectorOffset, PeekableIntIterator) - Static method in class org.apache.druid.segment.vector.VectorSelectorUtils
Helper used by ColumnarLongs, ColumnarDoubles, etc.
PossiblyNullColumnValueSelector<T> - Class in org.apache.druid.segment.join
A ColumnValueSelector that wraps a base selector but might also generate null values on demand.
PossiblyNullDimensionSelector - Class in org.apache.druid.segment.join
 
PossiblyNullDimensionSelector(DimensionSelector, BooleanSupplier) - Constructor for class org.apache.druid.segment.join.PossiblyNullDimensionSelector
 
postAggregate(GroupByQuery, IncrementalIndex<?>) - Static method in class org.apache.druid.query.groupby.GroupByQueryHelper
 
PostAggregator - Interface in org.apache.druid.query.aggregation
Functionally similar to an Aggregator.
PostAggregatorIds - Class in org.apache.druid.query.aggregation.post
 
PostAggregatorIds() - Constructor for class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
postAggregators(List<PostAggregator>) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
postAggregators(PostAggregator...) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
postAggregators(Collection<PostAggregator>) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
postAggregators(PostAggregator...) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
postFilters(List<Filter>) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
postFilters(List<Filter>) - Method in interface org.apache.druid.query.QueryMetrics
 
postFilters(List<Filter>) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
PostJoinCursor - Class in org.apache.druid.segment.join
postMergeQueryDecoration(QueryRunner<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
Wraps a QueryRunner.
postMergeQueryDecoration(QueryRunner<Result<TopNResultValue>>) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
postProcess(PostProcessingOperator<T>) - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
postProcess(Sequence<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQuery
Apply the havingSpec and limitSpec.
postProcess(QueryRunner<T>) - Method in interface org.apache.druid.query.PostProcessingOperator
 
postProcess(QueryRunner<T>) - Method in class org.apache.druid.query.TimewarpOperator
 
postProcess(QueryRunner<T>, long) - Method in class org.apache.druid.query.TimewarpOperator
 
PostProcessingOperator<T> - Interface in org.apache.druid.query
 
pQueue - Variable in class org.apache.druid.segment.IndexMerger.DictionaryMergeIterator
 
PreComputedHyperUniquesSerde - Class in org.apache.druid.query.aggregation.hyperloglog
 
PreComputedHyperUniquesSerde() - Constructor for class org.apache.druid.query.aggregation.hyperloglog.PreComputedHyperUniquesSerde
 
predicateFactory(ExtractionFn) - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
 
predicateFactory - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
PredicateValueMatcherFactory - Class in org.apache.druid.segment.filter
Creates ValueMatcher that apply a predicate to each value.
preFilters(List<Filter>) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
preFilters(List<Filter>) - Method in interface org.apache.druid.query.QueryMetrics
 
preFilters(List<Filter>) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
PrefixFilteredDimensionSpec - Class in org.apache.druid.query.dimension
 
PrefixFilteredDimensionSpec(DimensionSpec, String) - Constructor for class org.apache.druid.query.dimension.PrefixFilteredDimensionSpec
 
PreJoinableClause - Class in org.apache.druid.query.planning
Like JoinableClause, but contains a DataSource instead of a Joinable.
PreJoinableClause(String, DataSource, JoinType, JoinConditionAnalysis) - Constructor for class org.apache.druid.query.planning.PreJoinableClause
 
preMergeQueryDecoration(QueryRunner<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
preMergeQueryDecoration(QueryRunner<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
Wraps a QueryRunner.
preMergeQueryDecoration(QueryRunner<ScanResultValue>) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
 
preMergeQueryDecoration(QueryRunner<Result<SearchResultValue>>) - Method in class org.apache.druid.query.search.SearchQueryQueryToolChest
 
preMergeQueryDecoration(QueryRunner<Result<TimeseriesResultValue>>) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
preMergeQueryDecoration(QueryRunner<Result<TopNResultValue>>) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
prepareAggregations(List<AggregatorFactory>, List<PostAggregator>) - Static method in class org.apache.druid.query.Queries
Deprecated.
prepareAggregations(List<String>, List<AggregatorFactory>, List<PostAggregator>) - Static method in class org.apache.druid.query.Queries
Returns decorated post-aggregators, based on original un-decorated post-aggregators.
prepareForCache(boolean) - Method in interface org.apache.druid.query.CacheStrategy
Returns a function that converts from the QueryType's result type to something cacheable.
prepareForSegmentLevelCache() - Method in interface org.apache.druid.query.CacheStrategy
 
prepareResource(GroupByQuery) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Initializes resources required to run GroupByQueryQueryToolChest.mergeResults(QueryRunner) for a particular query.
prepareResource(GroupByQuery) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
prepareResource(GroupByQuery) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
preservesOrdering() - Method in class org.apache.druid.query.dimension.BaseFilteredDimensionSpec
 
preservesOrdering() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
preservesOrdering() - Method in interface org.apache.druid.query.dimension.DimensionSpec
 
preservesOrdering() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
preservesOrdering() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
preservesOrdering() - Method in interface org.apache.druid.query.extraction.ExtractionFn
Offers information on whether the extraction will preserve the original ordering of the values.
preservesOrdering() - Method in class org.apache.druid.query.extraction.FunctionalExtraction
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.LowerExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.StrlenExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.extraction.UpperExtractionFn
 
preservesOrdering() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
previousPowerOfTwo(int) - Static method in class org.apache.druid.query.groupby.epinephelinae.collection.HashTableUtils
Computes the previous power of two less than or equal to a given "n".
PrioritizedCallable<V> - Interface in org.apache.druid.query
 
PrioritizedExecutorService - Class in org.apache.druid.query
 
PrioritizedExecutorService(ThreadPoolExecutor, DruidProcessingConfig) - Constructor for class org.apache.druid.query.PrioritizedExecutorService
 
PrioritizedExecutorService(ThreadPoolExecutor, boolean, int, DruidProcessingConfig) - Constructor for class org.apache.druid.query.PrioritizedExecutorService
 
PrioritizedRunnable - Interface in org.apache.druid.query
 
PRIORITY_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
probability(int) - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
process(GroupByQuery, StorageAdapter, NonBlockingPool<ByteBuffer>, GroupByQueryConfig) - Static method in class org.apache.druid.query.groupby.epinephelinae.GroupByQueryEngineV2
 
process(GroupByQuery, GroupByQuery, Sequence<ResultRow>, GroupByQueryConfig, GroupByQueryResource, ObjectMapper, String, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.GroupByRowProcessor
Process the input of sequence "rows" (output by "subquery") based on "query" and returns a GroupByRowProcessor.ResultSupplier.
process(GroupByQuery, StorageAdapter, ByteBuffer, DateTime, Filter, Interval, GroupByQueryConfig) - Static method in class org.apache.druid.query.groupby.epinephelinae.vector.VectorGroupByEngine
 
process(GroupByQuery, StorageAdapter) - Method in class org.apache.druid.query.groupby.GroupByQueryEngine
 
process(GroupByQuery, StorageAdapter) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Process a groupBy query on a single StorageAdapter.
process(GroupByQuery, StorageAdapter) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
process(GroupByQuery, StorageAdapter) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
process(ScanQuery, Segment, ResponseContext) - Method in class org.apache.druid.query.scan.ScanQueryEngine
 
process(TimeseriesQuery, StorageAdapter) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryEngine
Run a single-segment, single-interval timeseries query on a particular adapter.
PROCESSED - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
PROCESSED_WITH_ERROR - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
Processing - Annotation Type in org.apache.druid.guice.annotations
 
processMergedRow(ColumnValueSelector) - Method in interface org.apache.druid.segment.DimensionMerger
Process a column value(s) (potentially multi-value) of a row from the given selector and update the DimensionMerger's internal state.
processMergedRow(ColumnValueSelector) - Method in class org.apache.druid.segment.NumericDimensionMergerV9
 
processMergedRow(ColumnValueSelector) - Method in class org.apache.druid.segment.StringDimensionMergerV9
 
processRowValsToUnsortedEncodedKeyComponent(Object, boolean) - Method in interface org.apache.druid.segment.DimensionIndexer
Given a single row value or list of row values (for multi-valued dimensions), update any internal data structures with the ingested values and return the row values as an array to be used within a Row key.
processRowValsToUnsortedEncodedKeyComponent(Object, boolean) - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
processRowValsToUnsortedEncodedKeyComponent(Object, boolean) - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
processRowValsToUnsortedEncodedKeyComponent(Object, boolean) - Method in class org.apache.druid.segment.LongDimensionIndexer
 
processRowValsToUnsortedEncodedKeyComponent(Object, boolean) - Method in class org.apache.druid.segment.StringDimensionIndexer
 
processSubqueryResult(GroupByQuery, GroupByQuery, GroupByQueryResource, Sequence<ResultRow>, boolean) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Called by GroupByQueryQueryToolChest.mergeResults(QueryRunner) when it needs to process a subquery.
processSubqueryResult(GroupByQuery, GroupByQuery, GroupByQueryResource, Sequence<ResultRow>, boolean) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
processSubqueryResult(GroupByQuery, GroupByQuery, GroupByQueryResource, Sequence<ResultRow>, boolean) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
processSubtotalsSpec(GroupByQuery, GroupByQueryResource, Sequence<ResultRow>) - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Called by GroupByQueryQueryToolChest.mergeResults(QueryRunner) when it needs to generate subtotals.
processSubtotalsSpec(GroupByQuery, GroupByQueryResource, Sequence<ResultRow>) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
processSubtotalsSpec(GroupByQuery, GroupByQueryResource, Sequence<ResultRow>) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DictionaryBuildingStringGroupByColumnSelectorStrategy
 
processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
Read a value from a grouping key and add it to the group by query result row, using the output name specified in a DimensionSpec.
processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 
progress() - Method in class org.apache.druid.segment.BaseProgressIndicator
 
progress() - Method in interface org.apache.druid.segment.ProgressIndicator
 
ProgressIndicator - Interface in org.apache.druid.segment
 
PropertiesModule - Class in org.apache.druid.guice
 
PropertiesModule(List<String>) - Constructor for class org.apache.druid.guice.PropertiesModule
 
pruneDependentPostAgg(List<PostAggregator>, String) - Static method in class org.apache.druid.query.aggregation.AggregatorUtil
returns the list of dependent postAggregators that should be calculated in order to calculate given postAgg
pull(Filter) - Static method in class org.apache.druid.segment.filter.cnf.CalciteCnfHelper
 
pullExistingSnapshot(String) - Method in class org.apache.druid.query.lookup.LookupSnapshotTaker
 
pullFromCache(boolean) - Method in interface org.apache.druid.query.CacheStrategy
A function that does the inverse of the operation that the function prepareForCache returns
pullFromSegmentLevelCache() - Method in interface org.apache.druid.query.CacheStrategy
 
pushDownNot(Filter) - Static method in class org.apache.druid.segment.filter.cnf.HiveCnfHelper
 
put(ResponseContext.BaseKey, Object) - Method in class org.apache.druid.query.context.ResponseContext
Associates the specified object with the specified key.
put(String, Object) - Method in class org.apache.druid.segment.Metadata
 
putAll(Map<String, Object>) - Method in class org.apache.druid.segment.Metadata
 
putFirst(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleMaxBufferAggregator
 
putFirst(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleMinBufferAggregator
 
putFirst(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleSumBufferAggregator
 
putFirst(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
Faster equivalent to aggregator.init(buf, position); aggregator.aggregate(buf, position, value);
putMeta(ByteBuffer, CompressionStrategy) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
Output the header values of the associating encoding format to the given outputStream.
putMeta(ByteBuffer, CompressionStrategy) - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
putMeta(ByteBuffer, CompressionStrategy) - Method in class org.apache.druid.segment.data.LongsLongEncodingWriter
 
putMeta(ByteBuffer, CompressionStrategy) - Method in class org.apache.druid.segment.data.TableLongEncodingWriter
 
PVALUE_FROM_ZTEST - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 

Q

quantiles - Variable in class org.apache.druid.query.aggregation.HistogramVisual
 
QUANTILES_DOUBLES_SKETCH_BUILD_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
QUANTILES_DOUBLES_SKETCH_MERGE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
QUANTILES_DOUBLES_SKETCH_TO_CDF_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
QUANTILES_DOUBLES_SKETCH_TO_HISTOGRAM_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
QUANTILES_DOUBLES_SKETCH_TO_QUANTILE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
QUANTILES_DOUBLES_SKETCH_TO_QUANTILES_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
QUANTILES_DOUBLES_SKETCH_TO_RANK_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
QUANTILES_DOUBLES_SKETCH_TO_STRING_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
Queries - Class in org.apache.druid.query
 
Queries() - Constructor for class org.apache.druid.query.Queries
 
query(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
query(SearchQuerySpec) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
query(String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
query(String, boolean) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
query(GroupByQuery) - Method in class org.apache.druid.query.groupby.DefaultGroupByQueryMetrics
 
Query<T> - Interface in org.apache.druid.query
 
query(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Pulls all information from the query object into dimensions of future metrics.
query(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
query - Variable in class org.apache.druid.query.search.SearchQueryExecutor
 
query(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetrics
 
query(TopNQuery) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
query(TopNQuery, StorageAdapter, TopNQueryMetrics) - Method in class org.apache.druid.query.topn.TopNQueryEngine
Do the thing - process a StorageAdapter into a Sequence of TopNResultValue, with one of the fine TopNAlgorithm available chosen based on the type of column being aggregated.
QUERY_CANCELLED - Static variable in exception org.apache.druid.query.QueryInterruptedException
 
QUERY_ID - Static variable in class org.apache.druid.query.BaseQuery
 
QUERY_INTERRUPTED - Static variable in exception org.apache.druid.query.QueryInterruptedException
 
QUERY_TIMEOUT - Static variable in exception org.apache.druid.query.QueryInterruptedException
 
QueryableIndex - Interface in org.apache.druid.segment
Direct interface to memory mapped segments.
QueryableIndexColumnSelectorFactory - Class in org.apache.druid.segment
The basic implementation of ColumnSelectorFactory over a historical segment (i.
QueryableIndexColumnSelectorFactory(QueryableIndex, VirtualColumns, boolean, Closer, ReadableOffset, Map<String, BaseColumn>) - Constructor for class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
 
QueryableIndexCursorSequenceBuilder - Class in org.apache.druid.segment
 
QueryableIndexCursorSequenceBuilder(QueryableIndex, Interval, VirtualColumns, ImmutableBitmap, long, long, boolean, Filter, ColumnSelectorBitmapIndexSelector) - Constructor for class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder
 
QueryableIndexCursorSequenceBuilder.AscendingTimestampCheckingOffset - Class in org.apache.druid.segment
 
QueryableIndexCursorSequenceBuilder.DescendingTimestampCheckingOffset - Class in org.apache.druid.segment
 
QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset - Class in org.apache.druid.segment
 
QueryableIndexIndexableAdapter - Class in org.apache.druid.segment
 
QueryableIndexIndexableAdapter(QueryableIndex) - Constructor for class org.apache.druid.segment.QueryableIndexIndexableAdapter
 
QueryableIndexSegment - Class in org.apache.druid.segment
 
QueryableIndexSegment(QueryableIndex, SegmentId) - Constructor for class org.apache.druid.segment.QueryableIndexSegment
 
QueryableIndexStorageAdapter - Class in org.apache.druid.segment
 
QueryableIndexStorageAdapter(QueryableIndex) - Constructor for class org.apache.druid.segment.QueryableIndexStorageAdapter
 
QueryableIndexStorageAdapter.FilterAnalysis - Class in org.apache.druid.segment
 
QueryableIndexVectorColumnSelectorFactory - Class in org.apache.druid.segment.vector
 
QueryableIndexVectorColumnSelectorFactory(QueryableIndex, ReadableVectorOffset, Closer, Map<String, BaseColumn>, VirtualColumns) - Constructor for class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
 
QueryContexts - Class in org.apache.druid.query
 
QueryContexts.Vectorize - Enum in org.apache.druid.query
 
QueryDataSource - Class in org.apache.druid.query
 
QueryDataSource(Query) - Constructor for class org.apache.druid.query.QueryDataSource
 
QueryException - Exception in org.apache.druid.query
Base serializable error response QueryResource and SqlResource are expected to emit the JSON form of this object when errors happen.
QueryException(Throwable, String, String, String) - Constructor for exception org.apache.druid.query.QueryException
 
QueryException(String, String, String, String) - Constructor for exception org.apache.druid.query.QueryException
 
queryId(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
queryId(String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
queryId(String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
queryId(String) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
queryId(String) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
queryId(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.getId() of the given query as dimension.
queryId(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
queryId(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
QueryInterruptedException - Exception in org.apache.druid.query
Exception representing a failed query.
QueryInterruptedException(String, String, String, String) - Constructor for exception org.apache.druid.query.QueryInterruptedException
 
QueryInterruptedException(Throwable) - Constructor for exception org.apache.druid.query.QueryInterruptedException
Creates a new QueryInterruptedException wrapping an underlying exception.
QueryInterruptedException(Throwable, String) - Constructor for exception org.apache.druid.query.QueryInterruptedException
 
QueryMetrics<QueryType extends Query<?>> - Interface in org.apache.druid.query
Abstraction wrapping ServiceMetricEvent.Builder and allowing to control what metrics are actually emitted, what dimensions do they have, etc.
QueryPlus<T> - Class in org.apache.druid.query
An immutable composite object of Query + extra stuff needed in QueryRunners.
QueryRunner<T> - Interface in org.apache.druid.query
 
QueryRunnerFactory<T,QueryType extends Query<T>> - Interface in org.apache.druid.query
An interface that defines the nitty gritty implementation details of a Query on a Segment
QueryRunnerFactoryConglomerate - Interface in org.apache.druid.query
 
QueryRunnerHelper - Class in org.apache.druid.query
 
QueryRunnerHelper() - Constructor for class org.apache.druid.query.QueryRunnerHelper
 
QuerySegmentSpec - Interface in org.apache.druid.query.spec
 
QuerySegmentWalker - Interface in org.apache.druid.query
An interface for query-handling entry points.
QueryToolChest<ResultType,QueryType extends Query<ResultType>> - Class in org.apache.druid.query
The broker-side (also used by server in some cases) API for a specific Query type.
QueryToolChest() - Constructor for class org.apache.druid.query.QueryToolChest
 
QueryToolChestWarehouse - Interface in org.apache.druid.query
 
queryType(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
queryType(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.getType() of the given query as dimension.
queryType(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
QueryUnsupportedException - Exception in org.apache.druid.query
This exception is for the query engine to surface when a query cannot be run.
QueryUnsupportedException(String, String, String, String) - Constructor for exception org.apache.druid.query.QueryUnsupportedException
 
QueryUnsupportedException(String) - Constructor for exception org.apache.druid.query.QueryUnsupportedException
 
QueryWatcher - Interface in org.apache.druid.query
This interface is in a very early stage and should not be considered stable.

R

RadiusBound - Class in org.apache.druid.collections.spatial.search
 
RadiusBound(float[], float, int) - Constructor for class org.apache.druid.collections.spatial.search.RadiusBound
 
RadiusBound(float[], float) - Constructor for class org.apache.druid.collections.spatial.search.RadiusBound
 
randomQueryId() - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
randomQueryId() - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
randomQueryId() - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
randomQueryId() - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
randomQueryId() - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
RangeIndexedInts - Class in org.apache.druid.segment.data
Reusable IndexedInts that returns sequences [0, 1, ..., N].
RangeIndexedInts() - Constructor for class org.apache.druid.segment.data.RangeIndexedInts
 
read(ByteBuffer, ColumnConfig, SmooshedFileMapper) - Method in class org.apache.druid.segment.column.ColumnDescriptor
 
read(int) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
 
read(long[], int, int, int) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
 
read(long[], int, int[], int, int, int) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
 
read(int) - Method in class org.apache.druid.segment.data.DeltaLongEncodingReader
 
read(ByteBuffer, ObjectStrategy<T>) - Static method in class org.apache.druid.segment.data.GenericIndexed
 
read(ByteBuffer, ObjectStrategy<T>, SmooshedFileMapper) - Static method in class org.apache.druid.segment.data.GenericIndexed
 
read(int) - Method in class org.apache.druid.segment.data.LongsLongEncodingReader
 
read(long[], int, int, int) - Method in class org.apache.druid.segment.data.LongsLongEncodingReader
 
read(int) - Method in class org.apache.druid.segment.data.TableLongEncodingReader
 
read(int) - Method in interface org.apache.druid.segment.join.table.IndexedTable.Reader
Read the value at a particular row number.
read(ByteBuffer, ColumnBuilder, ColumnConfig) - Method in interface org.apache.druid.segment.serde.ColumnPartSerde.Deserializer
 
read() - Method in class org.apache.druid.segment.transform.TransformingInputEntityReader
 
read() - Method in class org.apache.druid.segment.transform.TransformingInputSourceReader
 
ReadableOffset - Interface in org.apache.druid.segment.data
A ReadableOffset is an object that provides an integer offset, ostensibly as an index into an array.
ReadableVectorMatch - Interface in org.apache.druid.query.filter.vector
ReadableVectorOffset - Interface in org.apache.druid.segment.vector
Provides a batch of offsets, ostensibly as indexes into an array.
readFromByteBuffer(ByteBuffer) - Static method in class org.apache.druid.segment.data.VSizeColumnarInts
 
readFromByteBuffer(ByteBuffer) - Static method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
readFully(long, ByteBuffer) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
readFully(long, ByteBuffer) - Method in class org.apache.druid.segment.writeout.WriteOutBytes
Reads bytes from the byte sequences, represented by this WriteOutBytes, at the random position, into the given buffer.
readPair(ByteBuffer, int) - Static method in class org.apache.druid.query.aggregation.first.StringFirstLastUtils
 
readPairFromSelectors(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>) - Static method in class org.apache.druid.query.aggregation.first.StringFirstLastUtils
 
RealRoundingDistribution - Class in org.apache.druid.segment.generator
Rounds the output values from the sample() function of an AbstractRealDistribution.
RealRoundingDistribution(AbstractRealDistribution) - Constructor for class org.apache.druid.segment.generator.RealRoundingDistribution
 
RectangularBound - Class in org.apache.druid.collections.spatial.search
 
RectangularBound(float[], float[], int) - Constructor for class org.apache.druid.collections.spatial.search.RectangularBound
 
RectangularBound(float[], float[]) - Constructor for class org.apache.druid.collections.spatial.search.RectangularBound
 
ReferenceCountedObject - Interface in org.apache.druid.segment
Interface for an object that may have a reference acquired in the form of a Closeable.
ReferenceCountingCloseableObject<BaseObject extends Closeable> - Class in org.apache.druid.segment
ReferenceCountingCloseableObject implements something like automatic reference count-based resource management, backed by a Phaser.
ReferenceCountingCloseableObject(BaseObject) - Constructor for class org.apache.druid.segment.ReferenceCountingCloseableObject
 
ReferenceCountingIndexedTable - Class in org.apache.druid.segment.join.table
 
ReferenceCountingIndexedTable(IndexedTable) - Constructor for class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
 
ReferenceCountingSegment - Class in org.apache.druid.segment
Segment that is also a ReferenceCountingSegment, allowing query engines that operate directly on segments to track references so that dropping a Segment can be done safely to ensure there are no in-flight queries.
ReferenceCountingSegmentQueryRunner<T> - Class in org.apache.druid.query
 
ReferenceCountingSegmentQueryRunner(QueryRunnerFactory<T, Query<T>>, SegmentReference, SegmentDescriptor) - Constructor for class org.apache.druid.query.ReferenceCountingSegmentQueryRunner
 
referents - Variable in class org.apache.druid.segment.ReferenceCountingCloseableObject
 
ReflectionQueryToolChestWarehouse - Class in org.apache.druid.query
Deprecated.
ReflectionQueryToolChestWarehouse() - Constructor for class org.apache.druid.query.ReflectionQueryToolChestWarehouse
Deprecated.
 
RegexDimExtractionFn - Class in org.apache.druid.query.extraction
 
RegexDimExtractionFn(String, Integer, Boolean, String) - Constructor for class org.apache.druid.query.extraction.RegexDimExtractionFn
 
RegexDimExtractionFn(String, Boolean, String) - Constructor for class org.apache.druid.query.extraction.RegexDimExtractionFn
 
RegexDimFilter - Class in org.apache.druid.query.filter
 
RegexDimFilter(String, String, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.query.filter.RegexDimFilter
 
RegexDimFilter(String, String, ExtractionFn) - Constructor for class org.apache.druid.query.filter.RegexDimFilter
 
RegexFilter - Class in org.apache.druid.segment.filter
 
RegexFilter(String, Pattern, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.segment.filter.RegexFilter
 
RegexFilteredDimensionSpec - Class in org.apache.druid.query.dimension
 
RegexFilteredDimensionSpec(DimensionSpec, String) - Constructor for class org.apache.druid.query.dimension.RegexFilteredDimensionSpec
 
RegexpExtractExprMacro - Class in org.apache.druid.query.expression
 
RegexpExtractExprMacro() - Constructor for class org.apache.druid.query.expression.RegexpExtractExprMacro
 
RegexpLikeExprMacro - Class in org.apache.druid.query.expression
 
RegexpLikeExprMacro() - Constructor for class org.apache.druid.query.expression.RegexpLikeExprMacro
 
RegexSearchQuerySpec - Class in org.apache.druid.query.search
 
RegexSearchQuerySpec(String) - Constructor for class org.apache.druid.query.search.RegexSearchQuerySpec
 
RegisteredLookupExtractionFn - Class in org.apache.druid.query.lookup
 
RegisteredLookupExtractionFn(LookupExtractorFactoryContainerProvider, String, boolean, String, Boolean, Boolean) - Constructor for class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
registerKey(ResponseContext.BaseKey) - Static method in enum org.apache.druid.query.context.ResponseContext.Key
Primary way of registering context keys.
registerQueryFuture(Query<?>, ListenableFuture<?>) - Method in interface org.apache.druid.query.QueryWatcher
QueryRunners must use this method to register any pending queries.
registerSerde(String, ComplexMetricSerde) - Static method in class org.apache.druid.segment.serde.ComplexMetrics
Register a serde name -> ComplexMetricSerde mapping.
regrowthThreshold - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
relocate(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Inform all of our aggregators that they are being relocated.
relocate(int, int, ByteBuffer, ByteBuffer) - Method in interface org.apache.druid.query.aggregation.BufferAggregator
Relocates any cached objects.
relocate(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
 
relocate(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
 
relocate(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.druid.query.aggregation.FilteredVectorAggregator
 
relocate(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
 
relocate(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.druid.query.aggregation.NullableNumericVectorAggregator
 
relocate(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
relocate(int, int, ByteBuffer, ByteBuffer) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
relocate(int, int, ByteBuffer, ByteBuffer) - Method in interface org.apache.druid.query.aggregation.VectorAggregator
remoteAddress(String) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
remoteAddress(String) - Method in interface org.apache.druid.query.QueryMetrics
 
remoteAddress(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
remove(int) - Method in interface org.apache.druid.collections.bitmap.MutableBitmap
Remove the specified integer to the bitmap.
remove(int) - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
remove(int) - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
remove(int) - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
remove() - Method in class org.apache.druid.collections.IntegerSet.BitSetIterator
 
remove(Object) - Method in class org.apache.druid.collections.IntegerSet
 
remove(ResponseContext.BaseKey) - Method in class org.apache.druid.query.context.ResponseContext
 
remove() - Method in class org.apache.druid.query.groupby.epinephelinae.CloseableGrouperIterator
 
remove() - Method in class org.apache.druid.query.scan.ScanQueryLimitRowIterator
 
remove() - Method in class org.apache.druid.segment.IndexMerger.DictionaryMergeIterator
 
removeAll(Collection<?>) - Method in class org.apache.druid.collections.IntegerSet
 
removeAll(ReadableVectorMatch) - Method in class org.apache.druid.query.filter.vector.VectorMatch
Removes all rows from this object that occur in "other", in place, and returns a reference to this object.
removeAt(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
removeMax() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
removeMin() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
removeOffset(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
replaces(LookupExtractorFactory) - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
Deprecated.
replaces(LookupExtractorFactoryContainer) - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
 
reportBackPressureTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportBackPressureTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "time that channel is unreadable (backpressure)" metric.
reportBackPressureTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportBitmapConstructionTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportBitmapConstructionTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Reports the time spent constructing bitmap from QueryMetrics.preFilters(List) of the query.
reportBitmapConstructionTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportCpuTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportCpuTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "cpu time" metric.
reportCpuTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportMetric(String, Number) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportNodeBytes(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportNodeBytes(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "node bytes" metric.
reportNodeBytes(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportNodeTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportNodeTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "node time" metric.
reportNodeTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportNodeTimeToFirstByte(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportNodeTimeToFirstByte(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "time to first byte" metric.
reportNodeTimeToFirstByte(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportParallelMergeInputRows(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportParallelMergeInputRows(long) - Method in interface org.apache.druid.query.QueryMetrics
Reports total number of input rows processed by the broker during parallel merge.
reportParallelMergeInputRows(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportParallelMergeInputSequences(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportParallelMergeInputSequences(long) - Method in interface org.apache.druid.query.QueryMetrics
Reports total number of input sequences processed by the broker during parallel merge.
reportParallelMergeInputSequences(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportParallelMergeOutputRows(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportParallelMergeOutputRows(long) - Method in interface org.apache.druid.query.QueryMetrics
Reports broker total number of output rows after merging and combining input sequences (should be less than or equal to the value supplied to QueryMetrics.reportParallelMergeInputRows(long).
reportParallelMergeOutputRows(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportParallelMergeParallelism(int) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportParallelMergeParallelism(int) - Method in interface org.apache.druid.query.QueryMetrics
Reports number of parallel tasks the broker used to process the query during parallel merge.
reportParallelMergeParallelism(int) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportParallelMergeTaskCount(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportParallelMergeTaskCount(long) - Method in interface org.apache.druid.query.QueryMetrics
Reports broker total number of fork join pool tasks required to complete query
reportParallelMergeTaskCount(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportParallelMergeTotalCpuTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportParallelMergeTotalCpuTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Reports broker total CPU time in nanoseconds where fork join merge combine tasks were doing work
reportParallelMergeTotalCpuTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportPreFilteredRows(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportPreFilteredRows(long) - Method in interface org.apache.druid.query.QueryMetrics
Reports the number of rows to scan in the segment after applying QueryMetrics.preFilters(List).
reportPreFilteredRows(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportQueryBytes(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportQueryBytes(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "query bytes" metric.
reportQueryBytes(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportQueryTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportQueryTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "query time" metric.
reportQueryTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportSegmentAndCacheTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportSegmentAndCacheTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "segmentAndCache time" metric.
reportSegmentAndCacheTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportSegmentRows(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportSegmentRows(long) - Method in interface org.apache.druid.query.QueryMetrics
Reports the total number of rows in the processed segment.
reportSegmentRows(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
reportSegmentTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportSegmentTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "segment time" metric.
reportSegmentTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
ReportTimelineMissingSegmentQueryRunner<T> - Class in org.apache.druid.query
 
ReportTimelineMissingSegmentQueryRunner(SegmentDescriptor) - Constructor for class org.apache.druid.query.ReportTimelineMissingSegmentQueryRunner
 
ReportTimelineMissingSegmentQueryRunner(List<SegmentDescriptor>) - Constructor for class org.apache.druid.query.ReportTimelineMissingSegmentQueryRunner
 
reportWaitTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
reportWaitTime(long) - Method in interface org.apache.druid.query.QueryMetrics
Registers "wait time" metric.
reportWaitTime(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
requiredBufferCapacity(Grouper.KeySerde<KeyType>, AggregatorFactory[]) - Static method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
Returns the minimum buffer capacity required for this grouper.
requiredColumns() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
requiredColumns() - Method in interface org.apache.druid.segment.VirtualColumn
Returns a list of columns that this virtual column will access.
requiredFields() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
Get a list of fields that aggregators built by this factory will need to read.
requiredFields() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
requiredFields() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
reseedRandomGenerator(long) - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
reset(ColumnValueSelector) - Method in interface org.apache.druid.query.aggregation.AggregateCombiner
Resets this AggregateCombiner's state value to the value of the given selector, e.
reset(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.cardinality.HyperLogLogCollectorAggregateCombiner
 
reset(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregateCombiner
 
reset(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.last.StringLastAggregateCombiner
 
reset(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongSumAggregateCombiner
 
reset(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferHashGrouper
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferIntList
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.ConcurrentGrouper
 
reset() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
Reset the keySerde to its initial state.
reset() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
Reset the grouper to its initial state.
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
 
reset() - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
 
reset() - Method in interface org.apache.druid.query.groupby.epinephelinae.VectorGrouper
Reset the grouper to its initial state.
reset() - Method in class org.apache.druid.segment.BitmapOffset
 
reset() - Method in interface org.apache.druid.segment.Cursor
 
reset() - Method in class org.apache.druid.segment.data.Offset
Resets the Offset to the position it was created or cloned with.
reset() - Method in class org.apache.druid.segment.FilteredOffset
 
reset() - Method in interface org.apache.druid.segment.join.JoinMatcher
Clears any active matches.
reset() - Method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
 
reset() - Method in class org.apache.druid.segment.join.PostJoinCursor
 
reset() - Method in class org.apache.druid.segment.join.table.IndexedTableJoinMatcher
 
reset() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset
 
reset() - Method in class org.apache.druid.segment.RowBasedCursor
 
reset() - Method in class org.apache.druid.segment.RowWalker
 
reset() - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
reset() - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
reset() - Method in class org.apache.druid.segment.vector.BitmapVectorOffset
 
reset() - Method in class org.apache.druid.segment.vector.FilteredVectorOffset
 
reset() - Method in class org.apache.druid.segment.vector.NoFilterVectorOffset
 
reset() - Method in interface org.apache.druid.segment.vector.VectorCursor
Resets the cursor back to its original state.
reset() - Method in interface org.apache.druid.segment.vector.VectorOffset
Resets the object back to its original state.
RESOURCE_LIMIT_EXCEEDED - Static variable in exception org.apache.druid.query.QueryInterruptedException
 
ResourceLimitExceededException - Exception in org.apache.druid.query
Exception indicating that an operation failed because it exceeded some configured resource limit.
ResourceLimitExceededException(String, Object...) - Constructor for exception org.apache.druid.query.ResourceLimitExceededException
 
ResponseContext - Class in org.apache.druid.query.context
The context for storing and passing data between chains of QueryRunners.
ResponseContext() - Constructor for class org.apache.druid.query.context.ResponseContext
 
ResponseContext.BaseKey - Interface in org.apache.druid.query.context
The base interface of a response context key.
ResponseContext.Key - Enum in org.apache.druid.query.context
Keys associated with objects in the context.
ResponseContext.SerializationResult - Class in org.apache.druid.query.context
Serialization result of ResponseContext.
Result<T> - Class in org.apache.druid.query
 
Result(DateTime, T) - Constructor for class org.apache.druid.query.Result
 
resultArraySignature(GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
resultArraySignature(QueryType) - Method in class org.apache.druid.query.QueryToolChest
resultArraySignature(ScanQuery) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
 
resultArraySignature(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
resultArraySignature(TopNQuery) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
resultFormat(ScanQuery.ResultFormat) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
ResultGranularTimestampComparator<T> - Class in org.apache.druid.query
 
ResultGranularTimestampComparator(Granularity) - Constructor for class org.apache.druid.query.ResultGranularTimestampComparator
 
ResultMergeQueryRunner<T> - Class in org.apache.druid.query
 
ResultMergeQueryRunner(QueryRunner<T>, Function<Query<T>, Comparator<T>>, Function<Query<T>, BinaryOperator<T>>) - Constructor for class org.apache.druid.query.ResultMergeQueryRunner
 
ResultRow - Class in org.apache.druid.query.groupby
Used by GroupByQuery for results.
results(List<String>) - Method in interface org.apache.druid.query.groupby.epinephelinae.GroupByRowProcessor.ResultSupplier
Return a result sequence.
resultsAsArrays(GroupByQuery, Sequence<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
 
resultsAsArrays(QueryType, Sequence<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
Converts a sequence of this query's ResultType into arrays.
resultsAsArrays(ScanQuery, Sequence<ScanResultValue>) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
 
resultsAsArrays(TimeseriesQuery, Sequence<Result<TimeseriesResultValue>>) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
resultsAsArrays(TopNQuery, Sequence<Result<TopNResultValue>>) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
retainAll(Collection<?>) - Method in class org.apache.druid.collections.IntegerSet
 
RETURN_PARTIAL_RESULTS_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
rewriteRequiredColumns(Map<String, String>) - Method in interface org.apache.druid.query.filter.Filter
Return a copy of this filter that is identical to the this filter except that it operates on different columns, based on a renaming map where the key is the column to be renamed in the filter, and the value is the new column name.
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.query.filter.InDimFilter
 
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.BoundFilter
 
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.FalseFilter
 
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.LikeFilter
 
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.NotFilter
 
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.RegexFilter
 
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.SearchQueryFilter
 
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.TrueFilter
 
RhsRewriteCandidate - Class in org.apache.druid.segment.join.filter.rewrite
A candidate is an RHS column that appears in a filter, along with the value being filtered on, plus the joinable clause associated with the table that the RHS column is from.
RhsRewriteCandidate(JoinableClause, String, String, boolean) - Constructor for class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidate
 
RhsRewriteCandidates - Class in org.apache.druid.segment.join.filter.rewrite
 
RightTrimExprMacro() - Constructor for class org.apache.druid.query.expression.TrimExprMacro.RightTrimExprMacro
 
RoaringBitmapDecisionHelper - Class in org.apache.druid.query.search
 
RoaringBitmapFactory - Class in org.apache.druid.collections.bitmap
As the name suggests, this class instantiates bitmaps of the types WrappedRoaringBitmap and WrappedImmutableRoaringBitmap.
RoaringBitmapFactory() - Constructor for class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
RoaringBitmapFactory(boolean) - Constructor for class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
RoaringBitmapSerdeFactory - Class in org.apache.druid.segment.data
 
RoaringBitmapSerdeFactory(Boolean) - Constructor for class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
 
rowAdapter() - Method in class org.apache.druid.query.InlineDataSource
 
RowAdapter<RowType> - Interface in org.apache.druid.segment
An adapter between arbitrary types and the needs of callers that want to read specific columns out of those types (treating them as rows).
RowAdapters - Class in org.apache.druid.segment
Utility class for creating RowAdapter.
RowBasedColumnSelectorFactory<T> - Class in org.apache.druid.segment
A ColumnSelectorFactory that is based on an object supplier and a RowAdapter for that type of object.
RowBasedCursor<RowType> - Class in org.apache.druid.segment
A Cursor that is based on a stream of objects.
RowBasedExpressionColumnValueSelector - Class in org.apache.druid.segment.virtual
Expression column value selector that examines a set of 'unknown' type input bindings on a row by row basis, transforming the expression to handle multi-value list typed inputs as they are encountered.
RowBasedExpressionColumnValueSelector(ExpressionPlan, Expr.ObjectBinding) - Constructor for class org.apache.druid.segment.virtual.RowBasedExpressionColumnValueSelector
 
RowBasedGrouperHelper - Class in org.apache.druid.query.groupby.epinephelinae
This class contains shared code between GroupByMergingQueryRunnerV2 and GroupByRowProcessor.
RowBasedGrouperHelper.RowBasedKey - Class in org.apache.druid.query.groupby.epinephelinae
 
RowBasedIndexedTable<RowType> - Class in org.apache.druid.segment.join.table
An IndexedTable composed of a List-based table and Map-based indexes.
RowBasedIndexedTable(List<RowType>, RowAdapter<RowType>, RowSignature, Set<String>, String) - Constructor for class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
RowBasedSegment<RowType> - Class in org.apache.druid.segment
A Segment that is based on a stream of objects.
RowBasedSegment(SegmentId, Iterable<RowType>, RowAdapter<RowType>, RowSignature) - Constructor for class org.apache.druid.segment.RowBasedSegment
Create a row-based segment.
RowBasedStorageAdapter<RowType> - Class in org.apache.druid.segment
A StorageAdapter that is based on a stream of objects.
RowFilteringIndexAdapter - Class in org.apache.druid.segment
 
RowFilteringIndexAdapter(QueryableIndexIndexableAdapter, Predicate<RowPointer>) - Constructor for class org.apache.druid.segment.RowFilteringIndexAdapter
 
RowFunction - Interface in org.apache.druid.segment.transform
Interface for evaluating functions on rows.
RowIngestionMeters - Interface in org.apache.druid.segment.incremental
A collection of meters for row ingestion stats, with support for moving average calculations.
RowIngestionMetersFactory - Interface in org.apache.druid.segment.incremental
 
RowIngestionMetersTotals - Class in org.apache.druid.segment.incremental
 
RowIngestionMetersTotals(long, long, long, long) - Constructor for class org.apache.druid.segment.incremental.RowIngestionMetersTotals
 
RowIterator - Interface in org.apache.druid.segment
Extension of TimeAndDimsIterator, specialized for RowPointer instead of TimeAndDimsPointer.
RowNumCounter - Class in org.apache.druid.segment
Could be used as a simple "row number supplier" for RowPointer implementations.
RowNumCounter() - Constructor for class org.apache.druid.segment.RowNumCounter
 
RowNumCounter(int) - Constructor for class org.apache.druid.segment.RowNumCounter
 
RowOffsetMatcherFactory - Interface in org.apache.druid.query.filter
 
RowPointer - Class in org.apache.druid.segment
Extension of TimeAndDimsPointer, that keeps "row number" of the current data point in some collection of data points, that actually makes this data point to be called "row", and the collection, thus, "collection of rows".
RowPointer(ColumnValueSelector, ColumnValueSelector[], List<DimensionHandler>, ColumnValueSelector[], List<String>, IntSupplier) - Constructor for class org.apache.druid.segment.RowPointer
 
RowSignature - Class in org.apache.druid.segment.column
Type signature for a row in a Druid datasource or query result.
rowSignature() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
rowSignature() - Method in interface org.apache.druid.segment.join.table.IndexedTable
Returns the signature of this table, which includes all key columns (as well as other columns that can be selected, but are not keys).
rowSignature() - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
 
rowSignature() - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
RowSignature.Builder - Class in org.apache.druid.segment.column
 
RowWalker<T> - Class in org.apache.druid.segment
Used by RowBasedStorageAdapter and RowBasedCursor to walk through rows.
RTree - Class in org.apache.druid.collections.spatial
This RTree has been optimized to work with bitmap inverted indexes.
RTree(int, SplitStrategy, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.RTree
 
RTreeUtils - Class in org.apache.druid.collections.spatial
 
RTreeUtils() - Constructor for class org.apache.druid.collections.spatial.RTreeUtils
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.BySegmentQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.BySegmentSkippingQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.ChainedExecutionQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.ConcatQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.CPUTimeMetricQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.FinalizeResultsQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.FluentQueryRunnerBuilder.FluentQueryRunner
 
run(QueryPlus<ResultRow>, ResponseContext) - Method in class org.apache.druid.query.groupby.epinephelinae.GroupByMergingQueryRunnerV2
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.GroupByMergedQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.MetricsEmittingQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.NoopQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.PerSegmentOptimizingQueryRunner
 
run(QuerySegmentWalker, ResponseContext) - Method in class org.apache.druid.query.QueryPlus
 
run(QueryPlus<T>, ResponseContext) - Method in interface org.apache.druid.query.QueryRunner
Runs the given query and returns results in a time-ordered sequence.
run(QueryPlus<T>) - Method in interface org.apache.druid.query.QueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.ReferenceCountingSegmentQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.ReportTimelineMissingSegmentQueryRunner
 
run(QueryPlus<Result<SearchResultValue>>, ResponseContext) - Method in class org.apache.druid.query.search.SearchQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.spec.SpecificSegmentQueryRunner
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.SubqueryQueryRunner
 
run(TopNParams, TopNResultBuilder, int[], TopNQueryMetrics) - Method in class org.apache.druid.query.topn.AggregateTopNMetricFirstAlgorithm
 
run(Parameters, TopNResultBuilder, DimValSelector, TopNQueryMetrics) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
run(Parameters, TopNResultBuilder, DimValSelector, TopNQueryMetrics) - Method in interface org.apache.druid.query.topn.TopNAlgorithm
 
run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.UnionQueryRunner
 
runnerIntervalMappingIterator() - Method in class org.apache.druid.query.SinkQueryRunners
 
RuntimeInfoModule - Class in org.apache.druid.guice
 
RuntimeInfoModule() - Constructor for class org.apache.druid.guice.RuntimeInfoModule
 
RuntimeShapeInspector - Interface in org.apache.druid.query.monomorphicprocessing
 

S

safeBuild(QueryRunner<T>, QueryToolChest<T, ? extends Query<T>>, ServiceEmitter, AtomicLong, boolean) - Static method in class org.apache.druid.query.CPUTimeMetricQueryRunner
 
sample() - Method in class org.apache.druid.segment.generator.EnumeratedTreeDistribution
 
sample() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
 
sample() - Method in class org.apache.druid.segment.generator.SequentialDistribution
 
sample() - Method in class org.apache.druid.segment.transform.TransformingInputEntityReader
 
sample() - Method in class org.apache.druid.segment.transform.TransformingInputSourceReader
 
SCAN - Static variable in interface org.apache.druid.query.Query
 
scanAndAggregate(Parameters, DimValSelector, DimValAggregateStore) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
Returns the number of processed rows (i.
scanAndAggregate(DimensionSelector, BufferAggregator, int, Cursor, int[], ByteBuffer) - Method in interface org.apache.druid.query.topn.Generic1AggPooledTopNScanner
 
scanAndAggregate(DimensionSelector, BufferAggregator, int, Cursor, int[], ByteBuffer) - Method in class org.apache.druid.query.topn.Generic1AggPooledTopNScannerPrototype
Any changes to this method should be coordinated with TopNUtils, PooledTopNAlgorithm.computeSpecializedScanAndAggregateImplementations() and downstream methods.
scanAndAggregate(DimensionSelector, BufferAggregator, int, BufferAggregator, int, Cursor, int[], ByteBuffer) - Method in interface org.apache.druid.query.topn.Generic2AggPooledTopNScanner
 
scanAndAggregate(DimensionSelector, BufferAggregator, int, BufferAggregator, int, Cursor, int[], ByteBuffer) - Method in class org.apache.druid.query.topn.Generic2AggPooledTopNScannerPrototype
Any changes to this method should be coordinated with TopNUtils, PooledTopNAlgorithm.computeSpecializedScanAndAggregateImplementations() and downstream methods.
scanAndAggregate(TopNParams, Aggregator[][], TopNColumnAggregatesProcessor) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
scanAndAggregate(DimensionSelectorType, MetricSelectorType, BufferAggregatorType, int, HistoricalCursor, int[], ByteBuffer) - Method in interface org.apache.druid.query.topn.Historical1AggPooledTopNScanner
 
scanAndAggregate(HistoricalDimensionSelector, HistoricalColumnSelector, SimpleDoubleBufferAggregator, int, HistoricalCursor, int[], ByteBuffer) - Method in class org.apache.druid.query.topn.Historical1SimpleDoubleAggPooledTopNScannerPrototype
Any changes to this method should be coordinated with TopNUtils, PooledTopNAlgorithm.computeSpecializedScanAndAggregateImplementations() and downstream methods.
scanAndAggregate(SingleValueHistoricalDimensionSelector, HistoricalColumnSelector, SimpleDoubleBufferAggregator, int, HistoricalCursor, int[], ByteBuffer) - Method in class org.apache.druid.query.topn.HistoricalSingleValueDimSelector1SimpleDoubleAggPooledTopNScannerPrototype
Any changes to this method should be coordinated with TopNUtils, PooledTopNAlgorithm.computeSpecializedScanAndAggregateImplementations() and downstream methods.
scanAndAggregate(PooledTopNAlgorithm.PooledTopNParams, int[], BufferAggregator[]) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
scanAndAggregate(TopNParams, int[], Map<Comparable<?>, Aggregator[]>) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
scanAndAggregate(TopNQuery, Selector, Cursor, Aggregator[][]) - Method in class org.apache.druid.query.topn.types.NullableNumericTopNColumnAggregatesProcessor
 
scanAndAggregate(TopNQuery, DimensionSelector, Cursor, Aggregator[][]) - Method in class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
 
scanAndAggregate(TopNQuery, ValueSelectorType, Cursor, Aggregator[][]) - Method in interface org.apache.druid.query.topn.types.TopNColumnAggregatesProcessor
ScanQuery - Class in org.apache.druid.query.scan
 
ScanQuery(DataSource, QuerySegmentSpec, VirtualColumns, ScanQuery.ResultFormat, int, long, long, ScanQuery.Order, DimFilter, List<String>, Boolean, Map<String, Object>) - Constructor for class org.apache.druid.query.scan.ScanQuery
 
ScanQuery.Order - Enum in org.apache.druid.query.scan
 
ScanQuery.ResultFormat - Enum in org.apache.druid.query.scan
 
ScanQueryBuilder() - Constructor for class org.apache.druid.query.Druids.ScanQueryBuilder
 
ScanQueryConfig - Class in org.apache.druid.query.scan
 
ScanQueryConfig() - Constructor for class org.apache.druid.query.scan.ScanQueryConfig
 
ScanQueryEngine - Class in org.apache.druid.query.scan
 
ScanQueryEngine() - Constructor for class org.apache.druid.query.scan.ScanQueryEngine
 
ScanQueryLimitRowIterator - Class in org.apache.druid.query.scan
This iterator supports iteration through a Sequence returned by a ScanResultValue QueryRunner.
ScanQueryLimitRowIterator(QueryRunner<ScanResultValue>, QueryPlus<ScanResultValue>, ResponseContext) - Constructor for class org.apache.druid.query.scan.ScanQueryLimitRowIterator
 
ScanQueryOffsetSequence - Class in org.apache.druid.query.scan
A Sequence that wraps the results of a ScanQuery and skips a given number of rows.
ScanQueryOffsetSequence(Sequence<ScanResultValue>, long) - Constructor for class org.apache.druid.query.scan.ScanQueryOffsetSequence
 
ScanQueryQueryToolChest - Class in org.apache.druid.query.scan
 
ScanQueryQueryToolChest(ScanQueryConfig, GenericQueryMetricsFactory) - Constructor for class org.apache.druid.query.scan.ScanQueryQueryToolChest
 
ScanQueryRunnerFactory - Class in org.apache.druid.query.scan
 
ScanQueryRunnerFactory(ScanQueryQueryToolChest, ScanQueryEngine, ScanQueryConfig) - Constructor for class org.apache.druid.query.scan.ScanQueryRunnerFactory
 
ScanResultValue - Class in org.apache.druid.query.scan
 
ScanResultValue(String, List<String>, Object) - Constructor for class org.apache.druid.query.scan.ScanResultValue
 
ScanResultValueTimestampComparator - Class in org.apache.druid.query.scan
This comparator class supports comparisons of ScanResultValues based on the timestamp of their first event.
ScanResultValueTimestampComparator(ScanQuery) - Constructor for class org.apache.druid.query.scan.ScanResultValueTimestampComparator
 
SCHEMA_MAP - Static variable in class org.apache.druid.segment.generator.GeneratorBasicSchemas
 
search(Bound) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
 
search(SearchStrategy, Bound) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
 
search(ImmutableNode, Bound) - Method in class org.apache.druid.collections.spatial.search.GutmanSearchStrategy
 
search(ImmutableNode, Bound) - Method in interface org.apache.druid.collections.spatial.search.SearchStrategy
 
SEARCH - Static variable in interface org.apache.druid.query.Query
 
SEARCH_COLUMN_SELECTOR_STRATEGY_FACTORY - Static variable in class org.apache.druid.query.search.SearchQueryRunner
 
SearchBinaryFn - Class in org.apache.druid.query.search
 
SearchBinaryFn(SearchSortSpec, Granularity, int) - Constructor for class org.apache.druid.query.search.SearchBinaryFn
 
searchCurrentClassloader() - Method in class org.apache.druid.guice.ExtensionsConfig
 
SearchHit - Class in org.apache.druid.query.search
 
SearchHit(String, String, Integer) - Constructor for class org.apache.druid.query.search.SearchHit
 
SearchHit(String, String) - Constructor for class org.apache.druid.query.search.SearchHit
 
SearchQuery - Class in org.apache.druid.query.search
 
SearchQuery(DataSource, DimFilter, Granularity, int, QuerySegmentSpec, List<DimensionSpec>, SearchQuerySpec, SearchSortSpec, Map<String, Object>) - Constructor for class org.apache.druid.query.search.SearchQuery
 
SearchQueryBuilder() - Constructor for class org.apache.druid.query.Druids.SearchQueryBuilder
 
SearchQueryConfig - Class in org.apache.druid.query.search
 
SearchQueryConfig() - Constructor for class org.apache.druid.query.search.SearchQueryConfig
 
SearchQueryDecisionHelper - Class in org.apache.druid.query.search
 
SearchQueryDecisionHelper(double) - Constructor for class org.apache.druid.query.search.SearchQueryDecisionHelper
 
SearchQueryDimFilter - Class in org.apache.druid.query.filter
 
SearchQueryDimFilter(String, SearchQuerySpec, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.query.filter.SearchQueryDimFilter
 
SearchQueryDimFilter(String, SearchQuerySpec, ExtractionFn) - Constructor for class org.apache.druid.query.filter.SearchQueryDimFilter
 
SearchQueryExecutor - Class in org.apache.druid.query.search
 
SearchQueryExecutor(SearchQuery, Segment, List<DimensionSpec>) - Constructor for class org.apache.druid.query.search.SearchQueryExecutor
 
SearchQueryFilter - Class in org.apache.druid.segment.filter
 
SearchQueryFilter(String, SearchQuerySpec, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.segment.filter.SearchQueryFilter
 
SearchQueryMetrics - Interface in org.apache.druid.query.search
 
SearchQueryMetricsFactory - Interface in org.apache.druid.query.search
Implementations could be injected using PolyBind .optionBinder(binder, Key.get(SearchQueryMetricsFactory.class)) .addBinding("myCustomSearchQueryMetricsFactory") .to(MyCustomSearchQueryMetricsFactory.class); And then setting property: druid.query.search.queryMetricsFactory=myCustomSearchQueryMetricsFactory
SearchQueryQueryToolChest - Class in org.apache.druid.query.search
 
SearchQueryQueryToolChest(SearchQueryConfig) - Constructor for class org.apache.druid.query.search.SearchQueryQueryToolChest
 
SearchQueryQueryToolChest(SearchQueryConfig, SearchQueryMetricsFactory) - Constructor for class org.apache.druid.query.search.SearchQueryQueryToolChest
 
SearchQueryRunner - Class in org.apache.druid.query.search
 
SearchQueryRunner(Segment, SearchStrategySelector) - Constructor for class org.apache.druid.query.search.SearchQueryRunner
 
SearchQueryRunner.DoubleSearchColumnSelectorStrategy - Class in org.apache.druid.query.search
 
SearchQueryRunner.FloatSearchColumnSelectorStrategy - Class in org.apache.druid.query.search
 
SearchQueryRunner.LongSearchColumnSelectorStrategy - Class in org.apache.druid.query.search
 
SearchQueryRunner.SearchColumnSelectorStrategy<ValueSelectorType> - Interface in org.apache.druid.query.search
 
SearchQueryRunner.StringSearchColumnSelectorStrategy - Class in org.apache.druid.query.search
 
SearchQueryRunnerFactory - Class in org.apache.druid.query.search
 
SearchQueryRunnerFactory(SearchStrategySelector, SearchQueryQueryToolChest, QueryWatcher) - Constructor for class org.apache.druid.query.search.SearchQueryRunnerFactory
 
searchQuerySpec - Variable in class org.apache.druid.query.search.SearchQueryExecutor
 
SearchQuerySpec - Interface in org.apache.druid.query.search
 
SearchQuerySpecDimExtractionFn - Class in org.apache.druid.query.extraction
 
SearchQuerySpecDimExtractionFn(SearchQuerySpec) - Constructor for class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
SearchResultValue - Class in org.apache.druid.query.search
 
SearchResultValue(List<SearchHit>) - Constructor for class org.apache.druid.query.search.SearchResultValue
 
SearchSortSpec - Class in org.apache.druid.query.search
 
SearchSortSpec(StringComparator) - Constructor for class org.apache.druid.query.search.SearchSortSpec
 
SearchStrategy - Interface in org.apache.druid.collections.spatial.search
 
SearchStrategy - Class in org.apache.druid.query.search
 
SearchStrategy(SearchQuery) - Constructor for class org.apache.druid.query.search.SearchStrategy
 
SearchStrategySelector - Class in org.apache.druid.query.search
 
SearchStrategySelector(Supplier<SearchQueryConfig>) - Constructor for class org.apache.druid.query.search.SearchStrategySelector
 
SECONDARY_PARTITION_PRUNING_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
seek(int) - Method in interface org.apache.druid.segment.IndexMerger.IndexSeeker
 
seek(int) - Method in class org.apache.druid.segment.IndexMerger.IndexSeekerWithConversion
 
seek(int) - Method in interface org.apache.druid.segment.StringDimensionMergerV9.IndexSeeker
 
seek(int) - Method in class org.apache.druid.segment.StringDimensionMergerV9.IndexSeekerWithConversion
 
seek(int) - Method in class org.apache.druid.segment.StringDimensionMergerV9.IndexSeekerWithoutConversion
 
segment(String) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
segment(String) - Method in interface org.apache.druid.query.QueryMetrics
 
segment(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
segment - Variable in class org.apache.druid.query.search.SearchQueryExecutor
 
Segment - Interface in org.apache.druid.segment
The difference between this class and DataSegment is that DataSegment contains the segment metadata only, while this class represents the actual body of segment data, queryable.
SEGMENT_METADATA - Static variable in interface org.apache.druid.query.Query
 
SegmentAnalysis - Class in org.apache.druid.query.metadata.metadata
 
SegmentAnalysis(String, List<Interval>, Map<String, ColumnAnalysis>, long, long, Map<String, AggregatorFactory>, TimestampSpec, Granularity, Boolean) - Constructor for class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
SegmentAnalyzer - Class in org.apache.druid.query.metadata
 
SegmentAnalyzer(EnumSet<SegmentMetadataQuery.AnalysisType>) - Constructor for class org.apache.druid.query.metadata.SegmentAnalyzer
 
SegmentizerFactory - Interface in org.apache.druid.segment.loading
Factory that loads segment files from the disk and creates Segment object
SegmentizerModule - Class in org.apache.druid.jackson
 
SegmentizerModule() - Constructor for class org.apache.druid.jackson.SegmentizerModule
 
SegmentMetadataQuery - Class in org.apache.druid.query.metadata.metadata
 
SegmentMetadataQuery(DataSource, QuerySegmentSpec, ColumnIncluderator, Boolean, Map<String, Object>, EnumSet<SegmentMetadataQuery.AnalysisType>, Boolean, Boolean) - Constructor for class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
SegmentMetadataQuery.AnalysisType - Enum in org.apache.druid.query.metadata.metadata
 
SegmentMetadataQueryBuilder() - Constructor for class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
SegmentMetadataQueryConfig - Class in org.apache.druid.query.metadata
 
SegmentMetadataQueryConfig(String) - Constructor for class org.apache.druid.query.metadata.SegmentMetadataQueryConfig
 
SegmentMetadataQueryConfig() - Constructor for class org.apache.druid.query.metadata.SegmentMetadataQueryConfig
 
SegmentMetadataQueryQueryToolChest - Class in org.apache.druid.query.metadata
 
SegmentMetadataQueryQueryToolChest(SegmentMetadataQueryConfig) - Constructor for class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
SegmentMetadataQueryQueryToolChest(SegmentMetadataQueryConfig, GenericQueryMetricsFactory) - Constructor for class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
 
SegmentMetadataQueryRunnerFactory - Class in org.apache.druid.query.metadata
 
SegmentMetadataQueryRunnerFactory(SegmentMetadataQueryQueryToolChest, QueryWatcher) - Constructor for class org.apache.druid.query.metadata.SegmentMetadataQueryRunnerFactory
 
SegmentMissingException - Exception in org.apache.druid.segment
 
SegmentMissingException(String, Object...) - Constructor for exception org.apache.druid.segment.SegmentMissingException
 
SegmentMissingException(Throwable, String, Object...) - Constructor for exception org.apache.druid.segment.SegmentMissingException
 
SegmentReference - Interface in org.apache.druid.segment
A Segment with a associated references, such as ReferenceCountingSegment where the reference is the segment itself, and HashJoinSegment which wraps a ReferenceCountingSegment and also includes the associated list of JoinableClause
SegmentValidationException - Exception in org.apache.druid.segment
 
SegmentValidationException(String, Object...) - Constructor for exception org.apache.druid.segment.SegmentValidationException
 
SegmentValidationException(Throwable, String, Object...) - Constructor for exception org.apache.druid.segment.SegmentValidationException
 
SegmentWrangler - Interface in org.apache.druid.segment
Utility for creating Segment objects for concrete datasources.
segmentWriteOutMedium - Variable in class org.apache.druid.segment.NumericDimensionMergerV9
 
SegmentWriteOutMedium - Interface in org.apache.druid.segment.writeout
SegmentWriteOutMedium is an umbrella "resource disposer" for temporary buffers (in the form of WriteOutBytes, obtained by calling SegmentWriteOutMedium.makeWriteOutBytes() on the SegmentWriteOutMedium instance), that are used during new Druid segment creation, and other resources (see SegmentWriteOutMedium.getCloser()).
SegmentWriteOutMediumFactory - Interface in org.apache.druid.segment.writeout
 
SegmentWriteOutMediumModule - Class in org.apache.druid.segment.writeout
 
SegmentWriteOutMediumModule() - Constructor for class org.apache.druid.segment.writeout.SegmentWriteOutMediumModule
 
SELECT - Static variable in interface org.apache.druid.query.Query
 
selector(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
Creates a ColumnValueSelector for the aggregated column.
selector(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
selector(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
selector(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
SelectorDimFilter - Class in org.apache.druid.query.filter
 
SelectorDimFilter(String, String, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.query.filter.SelectorDimFilter
 
SelectorDimFilter(String, String, ExtractionFn) - Constructor for class org.apache.druid.query.filter.SelectorDimFilter
 
SelectorFilter - Class in org.apache.druid.segment.filter
This filter is to select the rows where the SelectorFilter.dimension has the SelectorFilter.value.
SelectorFilter(String, String) - Constructor for class org.apache.druid.segment.filter.SelectorFilter
 
SelectorFilter(String, String, FilterTuning) - Constructor for class org.apache.druid.segment.filter.SelectorFilter
 
selectorNeedsFoldCheck(BaseObjectColumnValueSelector<?>, ColumnCapabilities) - Static method in class org.apache.druid.query.aggregation.first.StringFirstLastUtils
Returns whether a given value selector *might* contain SerializablePairLongString objects.
SelectorPredicateFactory - Class in org.apache.druid.query.filter
A DruidPredicateFactory that checks if input values equal a specific, provided value.
SelectorPredicateFactory(String) - Constructor for class org.apache.druid.query.filter.SelectorPredicateFactory
 
SelectQuery - Class in org.apache.druid.query.select
Deprecated.
SelectQuery() - Constructor for class org.apache.druid.query.select.SelectQuery
Deprecated.
 
SequentialDistribution - Class in org.apache.druid.segment.generator
 
SequentialDistribution(Integer, Integer, List<Object>) - Constructor for class org.apache.druid.segment.generator.SequentialDistribution
 
SerializablePairLongString - Class in org.apache.druid.query.aggregation
 
SerializablePairLongString(Long, String) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongString
 
SerializablePairLongStringSerde - Class in org.apache.druid.query.aggregation
The SerializablePairLongStringSerde serializes a Long-String pair (SerializablePairLongString).
SerializablePairLongStringSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringSerde
 
serialize(ByteBuffer) - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
serialize(ByteBuffer) - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
serialize(DoubleMeanHolder, JsonGenerator, SerializerProvider) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder.Serializer
 
serialize(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.DoubleColumnSerializer
 
serialize(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.DoubleColumnSerializerV2
 
serialize(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.FloatColumnSerializer
 
serialize(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.FloatColumnSerializerV2
 
serialize(ColumnValueSelector<? extends T>) - Method in interface org.apache.druid.segment.GenericColumnSerializer
 
serialize(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.LongColumnSerializer
 
serialize(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.LongColumnSerializerV2
 
serialize(ColumnValueSelector<? extends T>) - Method in class org.apache.druid.segment.serde.ComplexColumnSerializer
 
serialize(ColumnValueSelector<? extends T>) - Method in class org.apache.druid.segment.serde.LargeColumnSupportedComplexColumnSerializer
 
serializer - Variable in class org.apache.druid.segment.NumericDimensionMergerV9
 
Serializer - Interface in org.apache.druid.segment.serde
Main interface for "serializeable something" in Druid segment serialization.
SERIALIZER_UTILS - Static variable in interface org.apache.druid.segment.IndexMerger
 
serializerBuilder() - Static method in class org.apache.druid.segment.serde.ComplexColumnPartSerde
 
SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.ComplexColumnPartSerde.SerializerBuilder
 
serializerBuilder() - Static method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
 
SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
 
serializerBuilder() - Static method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde
 
SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde.SerializerBuilder
 
serializerBuilder() - Static method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2
 
SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2.SerializerBuilder
 
serializerBuilder() - Static method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde
 
SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.FloatNumericColumnPartSerde.SerializerBuilder
 
serializerBuilder() - Static method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2
 
SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2.SerializerBuilder
 
serializerBuilder() - Static method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde
 
SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.LongNumericColumnPartSerde.SerializerBuilder
 
serializerBuilder() - Static method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2
 
SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2.SerializerBuilder
 
serializeWith(ObjectMapper, int) - Method in class org.apache.druid.query.context.ResponseContext
Serializes the context given that the resulting string length is less than the provided limit.
server(String) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
SERVER - Static variable in class org.apache.druid.query.DruidMetrics
 
server(String) - Method in interface org.apache.druid.query.QueryMetrics
 
server(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
set(int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferIntList
 
set(int, Object) - Method in class org.apache.druid.query.groupby.ResultRow
 
set(IncrementalIndexRow) - Method in class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
 
set(Object) - Method in class org.apache.druid.segment.virtual.SingleInputBindings
 
setAggregateAllMetrics(boolean) - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
 
setAggregateTopNMetricFirst(boolean) - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
 
setAggregatorSpecs(List<AggregatorFactory>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setAggregatorSpecs(AggregatorFactory...) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setAt(int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
setBitmapIndex(Supplier<BitmapIndex>) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setBuffer(ByteBuffer) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
 
setBuffer(ByteBuffer) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
Data will be written starting from current position of the buffer, and the position of the buffer will be updated as content is written.
setBuffer(ByteBuffer) - Method in class org.apache.druid.segment.data.DeltaLongEncodingReader
 
setBuffer(ByteBuffer) - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
setBuffer(ByteBuffer) - Method in class org.apache.druid.segment.data.LongsLongEncodingReader
 
setBuffer(ByteBuffer) - Method in class org.apache.druid.segment.data.LongsLongEncodingWriter
 
setBuffer(ByteBuffer) - Method in class org.apache.druid.segment.data.TableLongEncodingReader
 
setBuffer(ByteBuffer) - Method in class org.apache.druid.segment.data.TableLongEncodingWriter
 
setComplexColumnSupplier(Supplier<? extends ComplexColumn>) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setConcurrentEventAdd(boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
setContext(Map<String, Object>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setCurrentOffset(int) - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
setCurrentOffset(int) - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
setCurrentOffset(int) - Method in class org.apache.druid.segment.SimpleSettableOffset
 
setCurrentOffsets(Interval) - Method in class org.apache.druid.query.vector.VectorCursorGranularizer
 
setDataSource(DataSource) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setDataSource(String) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setDataSource(Query) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setDefaultAnalysisTypes(EnumSet<SegmentMetadataQuery.AnalysisType>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryConfig
 
setDeserializeComplexMetrics(boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
setDictionaryEncoded(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setDictionaryEncodedColumnSupplier(Supplier<? extends DictionaryEncodedColumn<?>>) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setDictionaryValuesSorted(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setDictionaryValuesUnique(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setDimension(String, Object) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
setDimensions(List<DimensionSpec>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setDimensions(DimensionSpec...) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setDimFilter(DimFilter) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setEncodingFlag(byte) - Static method in class org.apache.druid.segment.data.CompressionFactory
 
setFileMapper(SmooshedFileMapper) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setFilterable(boolean) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setFilterable(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setGranularity(Granularity) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setHasBitmapIndexes(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setHasExtractionFn(boolean) - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
 
setHashTableBuffer(ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper.BufferGrouperOffsetHeapIndexUpdater
 
setHasMultipleValues(boolean) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setHasMultipleValues(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setHasMultipleValues(boolean) - Method in class org.apache.druid.segment.column.ColumnDescriptor.Builder
 
setHasNulls(boolean) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setHasNulls(ColumnCapabilities.Capable) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setHasNulls(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setHasNulls(ColumnCapabilities.Capable) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setHasSpatialIndexes(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setHavingSpec(HavingSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setIndexSchema(IncrementalIndexSchema) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
setInterval(QuerySegmentSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setInterval(List<Interval>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setInterval(Interval) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setInterval(String) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setLegacy(boolean) - Method in class org.apache.druid.query.scan.ScanQueryConfig
 
setLimit(int) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setLimitSpec(LimitSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setMaxBytesInMemory(long) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
setMaxIntermediateRows(int) - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
setMaxResults(int) - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
setMaxRowCount(int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
setNumericColumnSupplier(Supplier<? extends NumericColumn>) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setObjectsNotSorted() - Method in class org.apache.druid.segment.data.GenericIndexedWriter
 
setOutputStream(WriteOutBytes) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
 
setOutputStream(WriteOutBytes) - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
setOutputStream(WriteOutBytes) - Method in class org.apache.druid.segment.data.LongsLongEncodingWriter
 
setOutputStream(WriteOutBytes) - Method in class org.apache.druid.segment.data.TableLongEncodingWriter
 
setPostAggregatorSpecs(List<PostAggregator>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.AlwaysHavingSpec
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.AndHavingSpec
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.EqualToHavingSpec
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
 
setQuery(GroupByQuery) - Method in interface org.apache.druid.query.groupby.having.HavingSpec
Informs this HavingSpec that rows passed to "eval" will originate from a particular groupBy query.
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.LessThanHavingSpec
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.NeverHavingSpec
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.NotHavingSpec
 
setQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.having.OrHavingSpec
 
setQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setSearchStrategy(String) - Method in class org.apache.druid.query.search.SearchQueryConfig
 
setSelectionSize(int) - Method in class org.apache.druid.query.filter.vector.VectorMatch
Sets the valid selectionSize, and returns a reference to this object.
setSimpleTestingIndexSchema(AggregatorFactory...) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
A helper method to set a simple index schema with only metrics and default values for the other parameters.
setSimpleTestingIndexSchema(Boolean, AggregatorFactory...) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
A helper method to set a simple index schema with controllable metrics and rollup, and default values for the other parameters.
setSingleThreaded(boolean) - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
setSize(int) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
 
setSize(int) - Method in class org.apache.druid.segment.data.RangeIndexedInts
 
setSortFacts(boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.Builder
 
setSparseIndexed() - Method in interface org.apache.druid.segment.DimensionIndexer
This method will be called while building an IncrementalIndex whenever a known dimension column (either through an explicit schema on the ingestion spec, or auto-discovered while processing rows) is absent in any row that is processed, to allow an indexer to account for any missing rows if necessary.
setSparseIndexed() - Method in class org.apache.druid.segment.DoubleDimensionIndexer
 
setSparseIndexed() - Method in class org.apache.druid.segment.FloatDimensionIndexer
 
setSparseIndexed() - Method in class org.apache.druid.segment.LongDimensionIndexer
 
setSparseIndexed() - Method in class org.apache.druid.segment.StringDimensionIndexer
 
setSpatialIndex(Supplier<SpatialIndex>) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setSpillingAllowed(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
 
setSubtotalsSpec(List<List<String>>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
SettableColumnValueSelector<T> - Interface in org.apache.druid.segment.selector.settable
SettableColumnValueSelectors are used in QueryableIndexIndexableAdapter.RowIteratorImpl.
SettableDimensionValueSelector - Class in org.apache.druid.segment.selector.settable
Settable implementation of DimensionSelector.
SettableDimensionValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
SettableDoubleColumnValueSelector - Class in org.apache.druid.segment.selector.settable
 
SettableDoubleColumnValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableDoubleColumnValueSelector
 
SettableFloatColumnValueSelector - Class in org.apache.druid.segment.selector.settable
 
SettableFloatColumnValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableFloatColumnValueSelector
 
SettableLongColumnValueSelector - Class in org.apache.druid.segment.selector.settable
 
SettableLongColumnValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableLongColumnValueSelector
 
SettableObjectColumnValueSelector<T> - Class in org.apache.druid.segment.selector.settable
 
SettableObjectColumnValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableObjectColumnValueSelector
 
SettableValueDoubleColumnValueSelector - Class in org.apache.druid.segment.selector.settable
A BaseDoubleColumnValueSelector impl to return settable double value on calls to BaseDoubleColumnValueSelector.getDouble()
SettableValueDoubleColumnValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableValueDoubleColumnValueSelector
 
SettableValueFloatColumnValueSelector - Class in org.apache.druid.segment.selector.settable
A BaseFloatColumnValueSelector impl to return settable float value on calls to BaseFloatColumnValueSelector.getFloat()
SettableValueFloatColumnValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableValueFloatColumnValueSelector
 
SettableValueLongColumnValueSelector - Class in org.apache.druid.segment.selector.settable
A BaseLongColumnValueSelector impl to return settable long value on calls to BaseLongColumnValueSelector.getLong()
SettableValueLongColumnValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableValueLongColumnValueSelector
 
setType(ValueType) - Method in class org.apache.druid.segment.column.ColumnBuilder
 
setType(ValueType) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
 
setupEncodedValueWriter() - Method in class org.apache.druid.segment.StringDimensionMergerV9
 
setValue(int, int) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
 
setValue(int) - Method in class org.apache.druid.segment.data.SingleIndexedInt
 
setValue(long) - Method in class org.apache.druid.segment.selector.settable.SettableLongColumnValueSelector
Optimized method for assigning timestamps, that are known to never be null
setValue(double) - Method in class org.apache.druid.segment.selector.settable.SettableValueDoubleColumnValueSelector
 
setValue(float) - Method in class org.apache.druid.segment.selector.settable.SettableValueFloatColumnValueSelector
 
setValue(long) - Method in class org.apache.druid.segment.selector.settable.SettableValueLongColumnValueSelector
 
setValueFrom(ColumnValueSelector<?>) - Method in interface org.apache.druid.segment.selector.settable.SettableColumnValueSelector
 
setValueFrom(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
 
setValueFrom(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.selector.settable.SettableDoubleColumnValueSelector
 
setValueFrom(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.selector.settable.SettableFloatColumnValueSelector
 
setValueFrom(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.selector.settable.SettableLongColumnValueSelector
 
setValueFrom(ColumnValueSelector) - Method in class org.apache.druid.segment.selector.settable.SettableObjectColumnValueSelector
 
setValues(int[], int) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
Sets the values from the given array.
setValues(int, int) - Method in class org.apache.druid.segment.data.SliceIndexedInts
 
setValueType(ValueType) - Method in class org.apache.druid.segment.column.ColumnDescriptor.Builder
 
setVirtualColumns(VirtualColumns) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
setVirtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in interface org.apache.druid.query.filter.BooleanFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in interface org.apache.druid.query.filter.Filter
Determine if a filter *should* use a bitmap index based on information collected from the supplied BitmapIndexSelector.
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.query.filter.InDimFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.BoundFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.FalseFilter
 
shouldUseBitmapIndex(Filter, BitmapIndexSelector, FilterTuning) - Static method in class org.apache.druid.segment.filter.Filters
This method provides a "standard" implementation of Filter.shouldUseBitmapIndex(BitmapIndexSelector) which takes a Filter, a BitmapIndexSelector, and FilterTuning to determine if: a) the filter supports bitmap indexes for all required columns b) the filter tuning specifies that it should use the index c) the cardinality of the column is above the minimum threshold and below the maximum threshold to use the index If all these things are true, QueryableIndexStorageAdapter will utilize the indexes.
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.LikeFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.NotFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.SpatialFilter
 
shouldUseBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.TrueFilter
 
shouldVectorize(boolean) - Method in enum org.apache.druid.query.QueryContexts.Vectorize
 
shouldVectorize(Query<?>, VirtualColumns, ColumnInspector) - Static method in class org.apache.druid.segment.VirtualColumns
 
shutdown() - Method in class org.apache.druid.query.PrioritizedExecutorService
 
shutdownNow() - Method in class org.apache.druid.query.PrioritizedExecutorService
 
SimpleAscendingOffset - Class in org.apache.druid.segment
 
SimpleAscendingOffset(int) - Constructor for class org.apache.druid.segment.SimpleAscendingOffset
 
SimpleDescendingOffset - Class in org.apache.druid.segment
 
SimpleDescendingOffset(int) - Constructor for class org.apache.druid.segment.SimpleDescendingOffset
 
SimpleDoubleAggregatorFactory - Class in org.apache.druid.query.aggregation
This is an abstract class inherited by various AggregatorFactory implementations that consume double input and produce double output on aggregation.
SimpleDoubleAggregatorFactory(ExprMacroTable, String, String, String) - Constructor for class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
SimpleDoubleBufferAggregator - Class in org.apache.druid.query.aggregation
 
SimpleDoubleBufferAggregator(BaseDoubleColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
 
SimpleFloatAggregatorFactory - Class in org.apache.druid.query.aggregation
 
SimpleFloatAggregatorFactory(ExprMacroTable, String, String, String) - Constructor for class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
SimpleFloatBufferAggregator - Class in org.apache.druid.query.aggregation
 
SimpleLongAggregatorFactory - Class in org.apache.druid.query.aggregation
This is an abstract class inherited by various AggregatorFactory implementations that consume long input and produce long output on aggregation.
SimpleLongAggregatorFactory(ExprMacroTable, String, String, String) - Constructor for class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
SimpleLongBufferAggregator - Class in org.apache.druid.query.aggregation
 
SimpleQueryableIndex - Class in org.apache.druid.segment
 
SimpleQueryableIndex(Interval, Indexed<String>, BitmapFactory, Map<String, Supplier<ColumnHolder>>, SmooshedFileMapper, Metadata, boolean) - Constructor for class org.apache.druid.segment.SimpleQueryableIndex
 
SimpleQueryableIndex(Interval, List<String>, Indexed<String>, BitmapFactory, Map<String, Supplier<ColumnHolder>>, SmooshedFileMapper, Metadata, Supplier<Map<String, DimensionHandler>>) - Constructor for class org.apache.druid.segment.SimpleQueryableIndex
 
SimpleSettableOffset - Class in org.apache.druid.segment
 
SimpleSettableOffset() - Constructor for class org.apache.druid.segment.SimpleSettableOffset
 
SingleIndexedInt - Class in org.apache.druid.segment.data
Reusable IndexedInts that represents a sequence of a solo value [X].
SingleIndexedInt() - Constructor for class org.apache.druid.segment.data.SingleIndexedInt
 
SingleInputBindings - Class in org.apache.druid.segment.virtual
 
SingleInputBindings() - Constructor for class org.apache.druid.segment.virtual.SingleInputBindings
 
SingleLongInputCachingExpressionColumnValueSelector - Class in org.apache.druid.segment.virtual
Like ExpressionColumnValueSelector, but caches the most recently computed value and re-uses it in the case of runs in the underlying column.
SingleLongInputCachingExpressionColumnValueSelector(ColumnValueSelector, Expr, boolean) - Constructor for class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
 
SingleLongInputCachingExpressionColumnValueSelector.LruEvalCache - Class in org.apache.druid.segment.virtual
 
SingleScanTimeDimensionSelector - Class in org.apache.druid.segment
A special DimensionSelector for projected time columns - it assumes time values are scanned once and values are grouped together (i.e.
SingleScanTimeDimensionSelector(BaseLongColumnValueSelector, ExtractionFn, boolean) - Constructor for class org.apache.druid.segment.SingleScanTimeDimensionSelector
 
SingleStringInputCachingExpressionColumnValueSelector - Class in org.apache.druid.segment.virtual
Like ExpressionColumnValueSelector, but caches results for the first CACHE_SIZE dictionary IDs of a string column.
SingleStringInputCachingExpressionColumnValueSelector(DimensionSelector, Expr) - Constructor for class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
 
SingleStringInputCachingExpressionColumnValueSelector.LruEvalCache - Class in org.apache.druid.segment.virtual
 
SingleStringInputDimensionSelector - Class in org.apache.druid.segment.virtual
A DimensionSelector decorator that computes an expression on top of it.
SingleStringInputDimensionSelector(DimensionSelector, Expr) - Constructor for class org.apache.druid.segment.virtual.SingleStringInputDimensionSelector
 
singleThreaded() - Method in class org.apache.druid.segment.data.GenericIndexed
Create a non-thread-safe Indexed, which may perform better than the underlying Indexed.
SingleValueColumnarIntsSerializer - Class in org.apache.druid.segment.data
Serializer that produces ColumnarInts.
SingleValueColumnarIntsSerializer() - Constructor for class org.apache.druid.segment.data.SingleValueColumnarIntsSerializer
 
singleValueDimensionVectorSelector(VectorSizeInspector, String) - Static method in class org.apache.druid.segment.vector.ConstantVectorSelectors
 
SingleValueDimensionVectorSelector - Interface in org.apache.druid.segment.vector
Vectorized selector for a singly-valued string-typed column.
SingleValueHistoricalDimensionSelector - Interface in org.apache.druid.segment.historical
 
SingleValueStringGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
SingleValueStringVectorValueMatcher - Class in org.apache.druid.query.filter.vector
 
SingleValueStringVectorValueMatcher(SingleValueDimensionVectorSelector) - Constructor for class org.apache.druid.query.filter.vector.SingleValueStringVectorValueMatcher
 
SinkQueryRunners<T> - Class in org.apache.druid.query
 
SinkQueryRunners(Iterable<Pair<Interval, QueryRunner<T>>>) - Constructor for class org.apache.druid.query.SinkQueryRunners
 
size() - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
 
size() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
size() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
size() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
size() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
size() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
size() - Method in class org.apache.druid.collections.IntegerSet
 
size() - Method in class org.apache.druid.collections.spatial.ImmutableRTree
 
size() - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Return the number of aggregators in this object.
size - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
size() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the number of elements currently in the table.
size() - Method in class org.apache.druid.segment.column.RowSignature
Returns the number of columns in this signature.
size() - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
 
size() - Method in interface org.apache.druid.segment.data.BitmapValues
 
size() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarDoublesSerializer
 
size() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarFloatsSerializer
 
size() - Method in class org.apache.druid.segment.data.BlockLayoutColumnarLongsSerializer
 
size() - Method in class org.apache.druid.segment.data.CachingIndexed
 
size() - Method in interface org.apache.druid.segment.data.ColumnarDoubles
 
size() - Method in interface org.apache.druid.segment.data.ColumnarDoublesSerializer
 
size() - Method in interface org.apache.druid.segment.data.ColumnarFloats
 
size() - Method in interface org.apache.druid.segment.data.ColumnarFloatsSerializer
 
size() - Method in interface org.apache.druid.segment.data.ColumnarLongs
 
size() - Method in interface org.apache.druid.segment.data.ColumnarLongsSerializer
 
size() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
 
size() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSerializer
 
size() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarFloatsSerializer
 
size() - Method in class org.apache.druid.segment.data.EntireLayoutColumnarLongsSerializer
 
size() - Method in class org.apache.druid.segment.data.GenericIndexed
 
size() - Method in class org.apache.druid.segment.data.ImmutableBitmapValues
 
size() - Method in interface org.apache.druid.segment.data.Indexed
 
size() - Method in interface org.apache.druid.segment.data.IndexedInts
 
size() - Method in class org.apache.druid.segment.data.IntermediateColumnarLongsSerializer
 
size() - Method in class org.apache.druid.segment.data.ListIndexed
 
size() - Method in class org.apache.druid.segment.data.RangeIndexedInts
 
size() - Method in class org.apache.druid.segment.data.SingleIndexedInt
 
size() - Method in class org.apache.druid.segment.data.SliceIndexedInts
 
size() - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
size() - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
size() - Method in class org.apache.druid.segment.data.ZeroIndexedInts
 
size() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
size(T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.ByteFieldWriter
 
size(T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.FieldWriter
 
size(T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.IntFieldWriter
 
size(T) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
 
size() - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
size() - Method in class org.apache.druid.segment.writeout.WriteOutBytes
Returns the number of bytes written to this WriteOutBytes so far.
SKETCH_MERGE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
skip(IntIterator, int) - Static method in class org.apache.druid.segment.IntIteratorUtils
Implements IntIterator.skip(int).
SKIP_EMPTY_BUCKETS - Static variable in class org.apache.druid.query.timeseries.TimeseriesQuery
 
SKIP_POSITION_VALUE - Static variable in interface org.apache.druid.query.topn.TopNAlgorithm
 
skipTo(String) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm.BaseArrayProvider
 
skipTo(String) - Method in interface org.apache.druid.query.topn.TopNMetricSpecBuilder
 
skipToDateTime(DateTime, boolean) - Method in class org.apache.druid.segment.RowWalker
 
SliceIndexedInts - Class in org.apache.druid.segment.data
Reusable IndexedInts, that could represent a sub-sequence ("slice") in a larger IndexedInts object.
SliceIndexedInts(IndexedInts) - Constructor for class org.apache.druid.segment.data.SliceIndexedInts
 
smear(int) - Static method in class org.apache.druid.query.groupby.epinephelinae.Groupers
This method was rewritten in Java from an intermediate step of the Murmur hash function in https://github.com/aappleby/smhasher/blob/master/src/MurmurHash3.cpp, which contained the following header: MurmurHash3 was written by Austin Appleby, and is placed in the public domain.
smileMapper() - Method in class org.apache.druid.jackson.JacksonModule
 
snapshot(ColumnCapabilities, ColumnCapabilities.CoercionLogic) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
SortedIntIntersectionIterator - Class in org.apache.druid.segment.join.table
Iterates over the intersection of an array of sorted int lists.
sortingOrderHasNonGroupingFields(DefaultLimitSpec, List<DimensionSpec>) - Static method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
Check if a limitSpec has columns in the sorting order that are not part of the grouping fields represented by `dimensions`.
sortSpec(SearchSortSpec) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
 
spaceNeeded() - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
Return the amount of buffer bytes needed by all aggregators wrapped up in this object.
SpatialDimensionRowTransformer - Class in org.apache.druid.segment.incremental
We throw away all invalid spatial dimensions
SpatialDimensionRowTransformer(List<SpatialDimensionSchema>) - Constructor for class org.apache.druid.segment.incremental.SpatialDimensionRowTransformer
 
SpatialDimFilter - Class in org.apache.druid.query.filter
 
SpatialDimFilter(String, Bound, FilterTuning) - Constructor for class org.apache.druid.query.filter.SpatialDimFilter
 
SpatialDimFilter(String, Bound) - Constructor for class org.apache.druid.query.filter.SpatialDimFilter
 
SpatialFilter - Class in org.apache.druid.segment.filter
 
SpatialFilter(String, Bound, FilterTuning) - Constructor for class org.apache.druid.segment.filter.SpatialFilter
 
SpatialIndex - Interface in org.apache.druid.segment.column
 
SpatialIndexColumnPartSupplier - Class in org.apache.druid.segment.serde
 
SpatialIndexColumnPartSupplier(ImmutableRTree) - Constructor for class org.apache.druid.segment.serde.SpatialIndexColumnPartSupplier
 
SpecializationService - Class in org.apache.druid.query.monomorphicprocessing
Manages class specialization during query processing.
SpecializationState<T> - Class in org.apache.druid.query.monomorphicprocessing
 
SpecializationState() - Constructor for class org.apache.druid.query.monomorphicprocessing.SpecializationState
 
SpecificSegmentQueryRunner<T> - Class in org.apache.druid.query.spec
 
SpecificSegmentQueryRunner(QueryRunner<T>, SpecificSegmentSpec) - Constructor for class org.apache.druid.query.spec.SpecificSegmentQueryRunner
 
SpecificSegmentSpec - Class in org.apache.druid.query.spec
 
SpecificSegmentSpec(SegmentDescriptor) - Constructor for class org.apache.druid.query.spec.SpecificSegmentSpec
 
SpillingGrouper<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
Grouper based around a single underlying BufferHashGrouper.
SpillingGrouper(Supplier<ByteBuffer>, Grouper.KeySerdeFactory<KeyType>, ColumnSelectorFactory, AggregatorFactory[], int, float, int, LimitedTemporaryStorage, ObjectMapper, boolean, DefaultLimitSpec, boolean, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
 
split(Node) - Method in class org.apache.druid.collections.spatial.split.GutmanSplitStrategy
This algorithm is from the original paper.
split(Node) - Method in interface org.apache.druid.collections.spatial.split.SplitStrategy
 
splitColumnName(String) - Static method in class org.apache.druid.segment.VirtualColumns
Split a dot-style columnName into the "main" columnName and the subColumn name after the dot.
splitFilter(JoinFilterPreAnalysis) - Static method in class org.apache.druid.segment.join.filter.JoinFilterAnalyzer
 
SplitStrategy - Interface in org.apache.druid.collections.spatial.split
 
splitVirtualColumns(VirtualColumns, List<VirtualColumn>, List<VirtualColumn>) - Method in class org.apache.druid.segment.join.filter.JoinableClauses
 
SQL_QUERY_ID - Static variable in class org.apache.druid.query.BaseQuery
 
sqlQueryId(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
sqlQueryId(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.getSqlQueryId() of the given query as dimension
sqlQueryId(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
standardRow() - Static method in class org.apache.druid.segment.RowAdapters
Returns a RowAdapter that handles any kind of input Row.
start() - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
This method will be called to start the LookupExtractor upon registered Calling start multiple times should return true if successfully started.
start() - Method in class org.apache.druid.segment.BaseProgressIndicator
 
start() - Method in interface org.apache.druid.segment.ProgressIndicator
 
startRecordingScanTime() - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
startRecordingScanTime() - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
Calls to this method and TopNQueryMetrics.stopRecordingScanTime() wrap scanning of each cursor, processed for the query.
startSection(String) - Method in class org.apache.druid.segment.BaseProgressIndicator
 
startSection(String) - Method in interface org.apache.druid.segment.ProgressIndicator
 
status(String) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
STATUS - Static variable in class org.apache.druid.query.DruidMetrics
 
status(String) - Method in interface org.apache.druid.query.QueryMetrics
 
status(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
STATUS_CODE - Static variable in exception org.apache.druid.query.QueryUnsupportedException
 
stop() - Method in class org.apache.druid.guice.LifecycleForkJoinPoolProvider
 
stop() - Method in class org.apache.druid.segment.BaseProgressIndicator
 
stop() - Method in interface org.apache.druid.segment.ProgressIndicator
 
stopRecordingScanTime() - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
stopRecordingScanTime() - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
Calls of TopNQueryMetrics.startRecordingScanTime() and this method wrap scanning of each cursor, processed for the query.
stopSection(String) - Method in class org.apache.druid.segment.BaseProgressIndicator
 
stopSection(String) - Method in interface org.apache.druid.segment.ProgressIndicator
 
storageAdapter - Variable in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
StorageAdapter - Interface in org.apache.druid.segment
 
storeDoubleAsFloat - Variable in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
storeDoubleAsFloat() - Static method in interface org.apache.druid.segment.column.ColumnHolder
 
storeInByteBuffer(ByteBuffer, int) - Method in class org.apache.druid.collections.spatial.Node
 
strategize(GroupByQuery) - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategySelector
 
strategize(SearchQuery) - Method in class org.apache.druid.query.search.SearchStrategySelector
 
STRATEGY_V1 - Static variable in class org.apache.druid.query.groupby.strategy.GroupByStrategySelector
 
STRATEGY_V2 - Static variable in class org.apache.druid.query.groupby.strategy.GroupByStrategySelector
 
StreamingMergeSortedGrouper<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
A streaming grouper which can aggregate sorted inputs.
STRING_ANY_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
STRING_FIRST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
STRING_LAST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
STRING_SEPARATOR - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
STRING_SEPARATOR - Static variable in class org.apache.druid.query.filter.DimFilterUtils
 
STRING_STRATEGY - Static variable in class org.apache.druid.segment.data.GenericIndexed
 
StringAnyAggregator - Class in org.apache.druid.query.aggregation.any
 
StringAnyAggregator(BaseObjectColumnValueSelector, int) - Constructor for class org.apache.druid.query.aggregation.any.StringAnyAggregator
 
StringAnyAggregatorFactory - Class in org.apache.druid.query.aggregation.any
 
StringAnyAggregatorFactory(String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
StringAnyBufferAggregator - Class in org.apache.druid.query.aggregation.any
 
StringAnyBufferAggregator(BaseObjectColumnValueSelector, int) - Constructor for class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
 
StringAnyVectorAggregator - Class in org.apache.druid.query.aggregation.any
 
StringAnyVectorAggregator(SingleValueDimensionVectorSelector, MultiValueDimensionVectorSelector, int) - Constructor for class org.apache.druid.query.aggregation.any.StringAnyVectorAggregator
 
StringCardinalityAggregatorColumnSelectorStrategy - Class in org.apache.druid.query.aggregation.cardinality.types
 
StringCardinalityAggregatorColumnSelectorStrategy() - Constructor for class org.apache.druid.query.aggregation.cardinality.types.StringCardinalityAggregatorColumnSelectorStrategy
 
StringColumnDoubleAggregatorWrapper - Class in org.apache.druid.query.aggregation
This class can be used to wrap Double Aggregator that consume double type columns to handle String type.
StringColumnDoubleAggregatorWrapper(BaseObjectColumnValueSelector, Function<BaseDoubleColumnValueSelector, Aggregator>, double) - Constructor for class org.apache.druid.query.aggregation.StringColumnDoubleAggregatorWrapper
 
StringColumnDoubleBufferAggregatorWrapper - Class in org.apache.druid.query.aggregation
This class can be used to wrap Double BufferAggregator that consume double type columns to handle String type.
StringColumnDoubleBufferAggregatorWrapper(BaseObjectColumnValueSelector, Function<BaseDoubleColumnValueSelector, BufferAggregator>, double) - Constructor for class org.apache.druid.query.aggregation.StringColumnDoubleBufferAggregatorWrapper
 
StringColumnFloatAggregatorWrapper - Class in org.apache.druid.query.aggregation
This class can be used to wrap Float Aggregator that consume float type columns to handle String type.
StringColumnFloatAggregatorWrapper(BaseObjectColumnValueSelector, Function<BaseFloatColumnValueSelector, Aggregator>, float) - Constructor for class org.apache.druid.query.aggregation.StringColumnFloatAggregatorWrapper
 
StringColumnFloatBufferAggregatorWrapper - Class in org.apache.druid.query.aggregation
This class can be used to wrap Float BufferAggregator that consume float type columns to handle String type.
StringColumnFloatBufferAggregatorWrapper(BaseObjectColumnValueSelector, Function<BaseFloatColumnValueSelector, BufferAggregator>, float) - Constructor for class org.apache.druid.query.aggregation.StringColumnFloatBufferAggregatorWrapper
 
StringColumnLongAggregatorWrapper - Class in org.apache.druid.query.aggregation
This class can be used to wrap Long Aggregator that consume long type columns to handle String type.
StringColumnLongAggregatorWrapper(BaseObjectColumnValueSelector, Function<BaseLongColumnValueSelector, Aggregator>, long) - Constructor for class org.apache.druid.query.aggregation.StringColumnLongAggregatorWrapper
 
StringColumnLongBufferAggregatorWrapper - Class in org.apache.druid.query.aggregation
This class can be used to wrap Long BufferAggregator that consume long type columns to handle String type.
StringColumnLongBufferAggregatorWrapper(BaseObjectColumnValueSelector, Function<BaseLongColumnValueSelector, BufferAggregator>, long) - Constructor for class org.apache.druid.query.aggregation.StringColumnLongBufferAggregatorWrapper
 
StringComparator - Class in org.apache.druid.query.ordering
 
StringComparator() - Constructor for class org.apache.druid.query.ordering.StringComparator
 
StringComparatorModule - Class in org.apache.druid.jackson
 
StringComparatorModule() - Constructor for class org.apache.druid.jackson.StringComparatorModule
 
StringComparatorModule.StringComparatorMixin - Interface in org.apache.druid.jackson
 
StringComparators - Class in org.apache.druid.query.ordering
 
StringComparators() - Constructor for class org.apache.druid.query.ordering.StringComparators
 
StringComparators.AlphanumericComparator - Class in org.apache.druid.query.ordering
 
StringComparators.LexicographicComparator - Class in org.apache.druid.query.ordering
 
StringComparators.NumericComparator - Class in org.apache.druid.query.ordering
 
StringComparators.StrlenComparator - Class in org.apache.druid.query.ordering
 
StringComparators.VersionComparator - Class in org.apache.druid.query.ordering
 
StringDictionaryEncodedColumn - Class in org.apache.druid.segment.column
 
StringDictionaryEncodedColumn(ColumnarInts, ColumnarMultiInts, CachingIndexed<String>) - Constructor for class org.apache.druid.segment.column.StringDictionaryEncodedColumn
 
StringDimensionHandler - Class in org.apache.druid.segment
 
StringDimensionHandler(String, DimensionSchema.MultiValueHandling, boolean, boolean) - Constructor for class org.apache.druid.segment.StringDimensionHandler
 
StringDimensionIndexer - Class in org.apache.druid.segment
 
StringDimensionIndexer(DimensionSchema.MultiValueHandling, boolean, boolean) - Constructor for class org.apache.druid.segment.StringDimensionIndexer
 
StringDimensionMergerV9 - Class in org.apache.druid.segment
 
StringDimensionMergerV9(String, IndexSpec, SegmentWriteOutMedium, ColumnCapabilities, ProgressIndicator, Closer) - Constructor for class org.apache.druid.segment.StringDimensionMergerV9
 
StringDimensionMergerV9.ConvertingBitmapValues - Class in org.apache.druid.segment
 
StringDimensionMergerV9.IndexSeeker - Interface in org.apache.druid.segment
 
StringDimensionMergerV9.IndexSeekerWithConversion - Class in org.apache.druid.segment
Get old dictId from new dictId, and only support access in order
StringDimensionMergerV9.IndexSeekerWithoutConversion - Class in org.apache.druid.segment
 
StringFirstAggregateCombiner - Class in org.apache.druid.query.aggregation.first
 
StringFirstAggregateCombiner() - Constructor for class org.apache.druid.query.aggregation.first.StringFirstAggregateCombiner
 
StringFirstAggregator - Class in org.apache.druid.query.aggregation.first
 
StringFirstAggregator(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>, int, boolean) - Constructor for class org.apache.druid.query.aggregation.first.StringFirstAggregator
 
StringFirstAggregatorFactory - Class in org.apache.druid.query.aggregation.first
 
StringFirstAggregatorFactory(String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
StringFirstBufferAggregator - Class in org.apache.druid.query.aggregation.first
 
StringFirstBufferAggregator(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>, int, boolean) - Constructor for class org.apache.druid.query.aggregation.first.StringFirstBufferAggregator
 
StringFirstFoldingAggregatorFactory - Class in org.apache.druid.query.aggregation.first
For backwards compatibility; equivalent to a regular StringFirstAggregatorFactory.
StringFirstFoldingAggregatorFactory(String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.first.StringFirstFoldingAggregatorFactory
 
StringFirstLastUtils - Class in org.apache.druid.query.aggregation.first
 
StringFirstLastUtils() - Constructor for class org.apache.druid.query.aggregation.first.StringFirstLastUtils
 
StringFormatExtractionFn - Class in org.apache.druid.query.extraction
 
StringFormatExtractionFn(String, StringFormatExtractionFn.NullHandling) - Constructor for class org.apache.druid.query.extraction.StringFormatExtractionFn
 
StringFormatExtractionFn(String) - Constructor for class org.apache.druid.query.extraction.StringFormatExtractionFn
 
StringFormatExtractionFn.NullHandling - Enum in org.apache.druid.query.extraction
 
StringGroupByColumnSelectorStrategy - Class in org.apache.druid.query.groupby.epinephelinae.column
 
StringGroupByColumnSelectorStrategy(IntFunction<String>, ColumnCapabilities) - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 
StringLastAggregateCombiner - Class in org.apache.druid.query.aggregation.last
 
StringLastAggregateCombiner() - Constructor for class org.apache.druid.query.aggregation.last.StringLastAggregateCombiner
 
StringLastAggregator - Class in org.apache.druid.query.aggregation.last
 
StringLastAggregator(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>, int, boolean) - Constructor for class org.apache.druid.query.aggregation.last.StringLastAggregator
 
StringLastAggregatorFactory - Class in org.apache.druid.query.aggregation.last
 
StringLastAggregatorFactory(String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
StringLastBufferAggregator - Class in org.apache.druid.query.aggregation.last
 
StringLastBufferAggregator(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>, int, boolean) - Constructor for class org.apache.druid.query.aggregation.last.StringLastBufferAggregator
 
StringLastFoldingAggregatorFactory - Class in org.apache.druid.query.aggregation.last
For backwards compatibility; equivalent to a regular StringLastAggregatorFactory.
StringLastFoldingAggregatorFactory(String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.last.StringLastFoldingAggregatorFactory
 
StringRuntimeShape - Class in org.apache.druid.query.monomorphicprocessing
Class to be used to obtain String representation of runtime shape of one or several HotLoopCallees.
StringSearchColumnSelectorStrategy() - Constructor for class org.apache.druid.query.search.SearchQueryRunner.StringSearchColumnSelectorStrategy
 
StringTopNColumnAggregatesProcessor - Class in org.apache.druid.query.topn.types
 
StringTopNColumnAggregatesProcessor(ValueType) - Constructor for class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
 
STRLEN - Static variable in class org.apache.druid.query.ordering.StringComparators
 
STRLEN_CACHE_ID - Static variable in class org.apache.druid.query.ordering.StringComparators
 
STRLEN_NAME - Static variable in class org.apache.druid.query.ordering.StringComparators
 
StrlenComparator() - Constructor for class org.apache.druid.query.ordering.StringComparators.StrlenComparator
 
StrlenExtractionFn - Class in org.apache.druid.query.extraction
 
SUB_QUERY_ID - Static variable in class org.apache.druid.query.BaseQuery
 
submit(Callable<T>) - Method in class org.apache.druid.query.MetricsEmittingExecutorService
 
submit(Runnable) - Method in class org.apache.druid.query.PrioritizedExecutorService
 
submit(Runnable, T) - Method in class org.apache.druid.query.PrioritizedExecutorService
 
submit(Callable<T>) - Method in class org.apache.druid.query.PrioritizedExecutorService
 
subQueryId(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
subQueryId(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
Sets Query.getSubQueryId() of the given query as dimension.
subQueryId(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
SubqueryQueryRunner<T> - Class in org.apache.druid.query
If there's a subquery, run it instead of the outer query
SubqueryQueryRunner(QueryRunner<T>) - Constructor for class org.apache.druid.query.SubqueryQueryRunner
 
SubstringDimExtractionFn - Class in org.apache.druid.query.extraction
 
SubstringDimExtractionFn(int, Integer) - Constructor for class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
success(boolean) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
success(boolean) - Method in interface org.apache.druid.query.QueryMetrics
 
success(boolean) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
SUPPORTED_SIZES - Static variable in class org.apache.druid.segment.data.VSizeLongSerde
 
supportsBitmapIndex(BitmapIndexSelector) - Method in interface org.apache.druid.query.filter.BooleanFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in interface org.apache.druid.query.filter.Filter
Indicates whether this filter can return a bitmap index for filtering, based on the information provided by the input BitmapIndexSelector.
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.query.filter.InDimFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.BoundFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.FalseFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.LikeFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.NotFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.SpatialFilter
 
supportsBitmapIndex(BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.TrueFilter
 
supportsNestedQueryPushDown() - Method in interface org.apache.druid.query.groupby.strategy.GroupByStrategy
Returns whether this strategy supports pushing down outer queries.
supportsNestedQueryPushDown() - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV1
 
supportsNestedQueryPushDown() - Method in class org.apache.druid.query.groupby.strategy.GroupByStrategyV2
 
supportsPushDown() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
 
supportsRequiredColumnRewrite() - Method in interface org.apache.druid.query.filter.Filter
Returns true is this filter is able to return a copy of this filter that is identical to this filter except that it operates on different columns, based on a renaming map.
supportsRequiredColumnRewrite() - Method in class org.apache.druid.query.filter.InDimFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.BoundFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.FalseFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.LikeFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.NotFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.RegexFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.SearchQueryFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.SelectorFilter
 
supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.TrueFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in interface org.apache.druid.query.filter.BooleanFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in interface org.apache.druid.query.filter.Filter
Indicates whether this filter supports selectivity estimation.
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.query.filter.InDimFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.BoundFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.FalseFilter
 
supportsSelectivityEstimation(Filter, String, ColumnSelector, BitmapIndexSelector) - Static method in class org.apache.druid.segment.filter.Filters
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.LikeFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.NotFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.SelectorFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.SpatialFilter
 
supportsSelectivityEstimation(ColumnSelector, BitmapIndexSelector) - Method in class org.apache.druid.segment.filter.TrueFilter
 
SUPPRESSED_AGG_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
SuppressedAggregator(Aggregator) - Constructor for class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
SuppressedAggregatorFactory - Class in org.apache.druid.query.aggregation
This AggregatorFactory is meant for wrapping delegate aggregators for optimization purposes.
SuppressedAggregatorFactory(AggregatorFactory) - Constructor for class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
SuppressedAggregatorFactory.SuppressedAggregator - Class in org.apache.druid.query.aggregation
 
SuppressedAggregatorFactory.SuppressedBufferAggregator - Class in org.apache.druid.query.aggregation
 
SuppressedAggregatorFactory.SuppressedVectorAggregator - Class in org.apache.druid.query.aggregation
 
SuppressedBufferAggregator(BufferAggregator) - Constructor for class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
SuppressedVectorAggregator(VectorAggregator) - Constructor for class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 

T

TABLE_ENCODING_VERSION - Static variable in class org.apache.druid.segment.data.CompressionFactory
Table Encoding Header v1 : Byte 1 : version Byte 2 - 5 : table size Byte 6 - (6 + 8 * table size - 1) : table of encoding, where the ith 8-byte value is encoded as i
tableArenaSize - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
tableBuffer - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
TableDataSource - Class in org.apache.druid.query
 
TableDataSource(String) - Constructor for class org.apache.druid.query.TableDataSource
 
TableLongEncodingReader - Class in org.apache.druid.segment.data
 
TableLongEncodingReader(ByteBuffer) - Constructor for class org.apache.druid.segment.data.TableLongEncodingReader
 
TableLongEncodingWriter - Class in org.apache.druid.segment.data
 
TableLongEncodingWriter(Long2IntMap, LongList) - Constructor for class org.apache.druid.segment.data.TableLongEncodingWriter
 
tableStart - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
 
takeSnapshot(String, List<LookupBean>) - Method in class org.apache.druid.query.lookup.LookupSnapshotTaker
 
TASK_ID - Static variable in class org.apache.druid.query.DruidMetrics
 
TASK_STATUS - Static variable in class org.apache.druid.query.DruidMetrics
 
TASK_TYPE - Static variable in class org.apache.druid.query.DruidMetrics
 
TDIGEST_BUILD_SKETCH_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
TDIGEST_SKETCH_TO_QUANTILE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
TDIGEST_SKETCH_TO_QUANTILES_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
TemporaryStorageFullException - Exception in org.apache.druid.query.groupby.epinephelinae
 
TemporaryStorageFullException(long) - Constructor for exception org.apache.druid.query.groupby.epinephelinae.TemporaryStorageFullException
 
THETA_SKETCH_CONSTANT - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
THETA_SKETCH_TO_STRING - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
threshold(TopNQuery) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
 
threshold(int) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
threshold(TopNQuery) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
Sets TopNQuery.getThreshold() of the given query as dimension.
THROWN_AWAY - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
TIER - Static variable in class org.apache.druid.query.DruidMetrics
 
TIME_BOUNDARY - Static variable in interface org.apache.druid.query.Query
 
TIME_COLUMN_NAME - Static variable in interface org.apache.druid.segment.column.ColumnHolder
 
TIME_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
TimeAndDimsIterator - Interface in org.apache.druid.segment
TimeAndDimsIterator (in conjunction with TimeAndDimsPointer) is an Iterator-like abstraction, designed for allocation-free transformation, merging, combining and iteration over a stream of data points.
TimeAndDimsPointer - Class in org.apache.druid.segment
TimeAndDimsPointer is used in conjunction with TimeAndDimsIterator, it's an _immutable_ object that points to different logical data points, as TimeAndDimsIterator.moveToNext() is called.
TimeBoundaryQuery - Class in org.apache.druid.query.timeboundary
 
TimeBoundaryQuery(DataSource, QuerySegmentSpec, String, DimFilter, Map<String, Object>) - Constructor for class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
TimeBoundaryQueryBuilder() - Constructor for class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
 
TimeBoundaryQueryQueryToolChest - Class in org.apache.druid.query.timeboundary
 
TimeBoundaryQueryQueryToolChest() - Constructor for class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
TimeBoundaryQueryQueryToolChest(GenericQueryMetricsFactory) - Constructor for class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
 
TimeBoundaryQueryRunnerFactory - Class in org.apache.druid.query.timeboundary
 
TimeBoundaryQueryRunnerFactory(QueryWatcher) - Constructor for class org.apache.druid.query.timeboundary.TimeBoundaryQueryRunnerFactory
 
TimeBoundaryResultValue - Class in org.apache.druid.query.timeboundary
 
TimeBoundaryResultValue(Object) - Constructor for class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
 
TimeDimExtractionFn - Class in org.apache.druid.query.extraction
 
TimeDimExtractionFn(String, String, boolean) - Constructor for class org.apache.druid.query.extraction.TimeDimExtractionFn
 
TimeExtractionTopNAlgorithm - Class in org.apache.druid.query.topn
 
TimeExtractionTopNAlgorithm(StorageAdapter, TopNQuery) - Constructor for class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
TimeFormatExtractionFn - Class in org.apache.druid.query.extraction
 
TimeFormatExtractionFn(String, DateTimeZone, String, Granularity, boolean) - Constructor for class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
timeInRange(long) - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.AscendingTimestampCheckingOffset
 
timeInRange(long) - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.DescendingTimestampCheckingOffset
 
timeInRange(long) - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset
 
TIMEOUT_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
TIMESERIES - Static variable in interface org.apache.druid.query.Query
 
TimeseriesBinaryFn - Class in org.apache.druid.query.timeseries
 
TimeseriesBinaryFn(Granularity, List<AggregatorFactory>) - Constructor for class org.apache.druid.query.timeseries.TimeseriesBinaryFn
 
TimeseriesQuery - Class in org.apache.druid.query.timeseries
 
TimeseriesQuery(DataSource, QuerySegmentSpec, boolean, VirtualColumns, DimFilter, Granularity, List<AggregatorFactory>, List<PostAggregator>, int, Map<String, Object>) - Constructor for class org.apache.druid.query.timeseries.TimeseriesQuery
 
TimeseriesQueryEngine - Class in org.apache.druid.query.timeseries
 
TimeseriesQueryEngine() - Constructor for class org.apache.druid.query.timeseries.TimeseriesQueryEngine
Constructor for tests.
TimeseriesQueryEngine(NonBlockingPool<ByteBuffer>) - Constructor for class org.apache.druid.query.timeseries.TimeseriesQueryEngine
 
TimeseriesQueryMetrics - Interface in org.apache.druid.query.timeseries
Specialization of QueryMetrics for TimeseriesQuery.
TimeseriesQueryMetricsFactory - Interface in org.apache.druid.query.timeseries
Implementations could be injected using PolyBind .optionBinder(binder, Key.get(TimeseriesQueryMetricsFactory.class)) .addBinding("myCustomTimeseriesQueryMetricsFactory") .to(MyCustomTimeseriesQueryMetricsFactory.class); And then setting property: druid.query.timeseries.queryMetricsFactory=myCustomTimeseriesQueryMetricsFactory
TimeseriesQueryQueryToolChest - Class in org.apache.druid.query.timeseries
 
TimeseriesQueryQueryToolChest() - Constructor for class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
TimeseriesQueryQueryToolChest(TimeseriesQueryMetricsFactory) - Constructor for class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
 
TimeseriesQueryRunnerFactory - Class in org.apache.druid.query.timeseries
 
TimeseriesQueryRunnerFactory(TimeseriesQueryQueryToolChest, TimeseriesQueryEngine, QueryWatcher) - Constructor for class org.apache.druid.query.timeseries.TimeseriesQueryRunnerFactory
 
TimeseriesResultBuilder - Class in org.apache.druid.query.timeseries
 
TimeseriesResultBuilder(DateTime) - Constructor for class org.apache.druid.query.timeseries.TimeseriesResultBuilder
 
TimeseriesResultValue - Class in org.apache.druid.query.timeseries
 
TimeseriesResultValue(Map<String, Object>) - Constructor for class org.apache.druid.query.timeseries.TimeseriesResultValue
 
TIMESTAMP_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
TimestampCeilExprMacro - Class in org.apache.druid.query.expression
 
TimestampCeilExprMacro() - Constructor for class org.apache.druid.query.expression.TimestampCeilExprMacro
 
TimestampExtractExprMacro - Class in org.apache.druid.query.expression
 
TimestampExtractExprMacro() - Constructor for class org.apache.druid.query.expression.TimestampExtractExprMacro
 
TimestampExtractExprMacro.Unit - Enum in org.apache.druid.query.expression
 
TimestampFloorExprMacro - Class in org.apache.druid.query.expression
 
TimestampFloorExprMacro() - Constructor for class org.apache.druid.query.expression.TimestampFloorExprMacro
 
TimestampFloorExprMacro.TimestampFloorDynamicExpr - Class in org.apache.druid.query.expression
 
TimestampFloorExprMacro.TimestampFloorExpr - Class in org.apache.druid.query.expression
 
TimestampFormatExprMacro - Class in org.apache.druid.query.expression
 
TimestampFormatExprMacro() - Constructor for class org.apache.druid.query.expression.TimestampFormatExprMacro
 
timestampFunction() - Method in interface org.apache.druid.segment.RowAdapter
Returns a function that retrieves timestamps from rows.
TimestampParseExprMacro - Class in org.apache.druid.query.expression
 
TimestampParseExprMacro() - Constructor for class org.apache.druid.query.expression.TimestampParseExprMacro
 
TimestampShiftExprMacro - Class in org.apache.druid.query.expression
 
TimestampShiftExprMacro() - Constructor for class org.apache.druid.query.expression.TimestampShiftExprMacro
 
TimewarpOperator<T> - Class in org.apache.druid.query
TimewarpOperator is an example post-processing operator that maps current time to the latest period ending withing the specified data interval and truncates the query interval to discard data that would be mapped to the future.
TimewarpOperator(Interval, Period, DateTime) - Constructor for class org.apache.druid.query.TimewarpOperator
 
TmpFileSegmentWriteOutMedium - Class in org.apache.druid.segment.writeout
 
TmpFileSegmentWriteOutMediumFactory - Class in org.apache.druid.segment.writeout
 
toArray() - Method in class org.apache.druid.collections.IntegerSet
 
toBooleanIfPossible(DimensionDictionarySelector, boolean, Predicate<String>) - Static method in class org.apache.druid.segment.filter.ValueMatchers
If applying predicate to selector would always return a constant, returns that constant.
toByteBuffer(T) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
Serialize a key.
toBytes() - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
 
toBytes() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
toBytes() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
toBytes() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
toBytes() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
toBytes() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
toBytes() - Method in class org.apache.druid.collections.spatial.ImmutableRTree
 
toBytes() - Method in class org.apache.druid.query.aggregation.Histogram
 
toBytes() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
toBytes(ResourceHolder<ByteBuffer>) - Method in class org.apache.druid.segment.data.DecompressingByteBufferObjectStrategy
 
toBytes(ImmutableRTree) - Method in class org.apache.druid.segment.data.ImmutableRTreeObjectStrategy
 
toBytes(T) - Method in interface org.apache.druid.segment.data.ObjectStrategy
 
toBytes(Object) - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
Converts intermediate representation of aggregate to byte[].
toCnf(Filter) - Static method in class org.apache.druid.segment.filter.Filters
 
toFilter() - Method in class org.apache.druid.query.filter.AndDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
toFilter() - Method in interface org.apache.druid.query.filter.DimFilter
Returns a Filter that implements this DimFilter.
toFilter() - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
toFilter() - Method in class org.apache.druid.query.filter.FalseDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.InDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.NotDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.OrDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
toFilter() - Method in class org.apache.druid.query.filter.TrueDimFilter
 
toFilter(DimFilter) - Static method in class org.apache.druid.segment.filter.Filters
Convert a DimFilter to a Filter.
toFilters(List<DimFilter>) - Static method in class org.apache.druid.segment.filter.Filters
Convert a list of DimFilters to a list of Filters.
toImmutableBitmap() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
toImmutableBitmap(T) - Method in interface org.apache.druid.query.BitmapResultFactory
Unwraps bitmapResult back to ImmutableBitmap.
toImmutableBitmap(ImmutableBitmap) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
toInclude(ColumnIncluderator) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 
toIndexableAdapters(List<QueryableIndex>) - Static method in interface org.apache.druid.segment.IndexMerger
 
toIndexSeekers(List<IndexableAdapter>, ArrayList<IntBuffer>, String) - Method in class org.apache.druid.segment.StringDimensionMergerV9
 
toIntList(IntIterator) - Static method in class org.apache.druid.segment.IntIteratorUtils
 
toJson() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
toMap(GroupByQuery) - Method in class org.apache.druid.query.groupby.ResultRow
Returns a Map representation of the data in this row.
toMapBasedRow(GroupByQuery) - Method in class org.apache.druid.query.groupby.ResultRow
Returns a Row representation of the data in this row.
toMergedIndexRowIterator(TransformableRowIterator, int, List<DimensionMergerV9>) - Static method in interface org.apache.druid.segment.IndexMerger
This method applies DimensionMerger.convertSortedSegmentRowValuesToMergedRowValues(int, ColumnValueSelector) to all dimension column selectors of the given sourceRowIterator, using the given index number.
toNormalizedOrClauses(Filter) - Static method in class org.apache.druid.segment.filter.Filters
 
toOptimizedFilter() - Method in class org.apache.druid.query.filter.AbstractOptimizableDimFilter
 
toOptimizedFilter() - Method in interface org.apache.druid.query.filter.DimFilter
 
TOPN - Static variable in interface org.apache.druid.query.Query
 
TOPN - Static variable in class org.apache.druid.query.topn.TopNQuery
 
TopNAlgorithm<DimValSelector,Parameters extends TopNParams> - Interface in org.apache.druid.query.topn
 
TopNAlgorithmSelector - Class in org.apache.druid.query.topn
 
TopNAlgorithmSelector(int, int) - Constructor for class org.apache.druid.query.topn.TopNAlgorithmSelector
 
TopNBinaryFn - Class in org.apache.druid.query.topn
 
TopNBinaryFn(Granularity, DimensionSpec, TopNMetricSpec, int, List<AggregatorFactory>, List<PostAggregator>) - Constructor for class org.apache.druid.query.topn.TopNBinaryFn
 
TopNColumnAggregatesProcessor<ValueSelectorType> - Interface in org.apache.druid.query.topn.types
This ColumnSelectorStrategy is used by all TopNAlgorithm to provide selector value cardinality to TopNParams (perhaps unecessarily, but that is another matter), but is primarily used by HeapBasedTopNAlgorithm to serve as its value aggregates store.
TopNColumnAggregatesProcessorFactory - Class in org.apache.druid.query.topn.types
 
TopNColumnAggregatesProcessorFactory(ValueType) - Constructor for class org.apache.druid.query.topn.types.TopNColumnAggregatesProcessorFactory
 
TopNLexicographicResultBuilder - Class in org.apache.druid.query.topn
 
TopNLexicographicResultBuilder(DateTime, DimensionSpec, int, String, Comparator, List<AggregatorFactory>) - Constructor for class org.apache.druid.query.topn.TopNLexicographicResultBuilder
 
TopNMapFn - Class in org.apache.druid.query.topn
 
TopNMapFn(TopNQuery, TopNAlgorithm) - Constructor for class org.apache.druid.query.topn.TopNMapFn
 
TopNMetricSpec - Interface in org.apache.druid.query.topn
 
TopNMetricSpecBuilder<T> - Interface in org.apache.druid.query.topn
 
TopNNumericResultBuilder - Class in org.apache.druid.query.topn
 
TopNNumericResultBuilder(DateTime, DimensionSpec, String, int, Comparator, List<AggregatorFactory>, List<PostAggregator>) - Constructor for class org.apache.druid.query.topn.TopNNumericResultBuilder
 
TopNParams - Class in org.apache.druid.query.topn
 
TopNParams(ColumnSelectorPlus<TopNColumnAggregatesProcessor>, Cursor, int) - Constructor for class org.apache.druid.query.topn.TopNParams
 
TopNQuery - Class in org.apache.druid.query.topn
 
TopNQuery(DataSource, VirtualColumns, DimensionSpec, TopNMetricSpec, int, QuerySegmentSpec, DimFilter, Granularity, List<AggregatorFactory>, List<PostAggregator>, Map<String, Object>) - Constructor for class org.apache.druid.query.topn.TopNQuery
 
TopNQueryBuilder - Class in org.apache.druid.query.topn
A Builder for TopNQuery.
TopNQueryBuilder() - Constructor for class org.apache.druid.query.topn.TopNQueryBuilder
 
TopNQueryBuilder(TopNQuery) - Constructor for class org.apache.druid.query.topn.TopNQueryBuilder
 
TopNQueryConfig - Class in org.apache.druid.query.topn
 
TopNQueryConfig() - Constructor for class org.apache.druid.query.topn.TopNQueryConfig
 
TopNQueryEngine - Class in org.apache.druid.query.topn
 
TopNQueryEngine(NonBlockingPool<ByteBuffer>) - Constructor for class org.apache.druid.query.topn.TopNQueryEngine
 
TopNQueryMetrics - Interface in org.apache.druid.query.topn
Specialization of QueryMetrics for TopNQuery.
TopNQueryMetricsFactory - Interface in org.apache.druid.query.topn
Implementations could be injected using PolyBind .optionBinder(binder, Key.get(TopNQueryMetricsFactory.class)) .addBinding("myCustomTopNQueryMetricsFactory") .to(MyCustomTopNQueryMetricsFactory.class); And then setting property: druid.query.topN.queryMetricsFactory=myCustomTopNQueryMetricsFactory
TopNQueryQueryToolChest - Class in org.apache.druid.query.topn
 
TopNQueryQueryToolChest(TopNQueryConfig) - Constructor for class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
TopNQueryQueryToolChest(TopNQueryConfig, TopNQueryMetricsFactory) - Constructor for class org.apache.druid.query.topn.TopNQueryQueryToolChest
 
TopNQueryRunnerFactory - Class in org.apache.druid.query.topn
 
TopNQueryRunnerFactory(NonBlockingPool<ByteBuffer>, TopNQueryQueryToolChest, QueryWatcher) - Constructor for class org.apache.druid.query.topn.TopNQueryRunnerFactory
 
TopNResultBuilder - Interface in org.apache.druid.query.topn
 
TopNResultValue - Class in org.apache.druid.query.topn
 
TopNResultValue(List<?>) - Constructor for class org.apache.druid.query.topn.TopNResultValue
 
toResultRow(GroupByQuery, Row) - Static method in class org.apache.druid.query.groupby.GroupByQueryHelper
 
toSingleEventScanResultValues() - Method in class org.apache.druid.query.scan.ScanResultValue
 
toStorageAdapter() - Method in class org.apache.druid.segment.AbstractIndex
 
toStorageAdapter() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
 
toStorageAdapter() - Method in class org.apache.druid.segment.SimpleQueryableIndex
 
toString() - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
 
toString() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
toString() - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
toString() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
 
toString() - Method in class org.apache.druid.guice.ExtensionsConfig
 
toString() - Method in class org.apache.druid.guice.ModulesConfig
 
toString() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.Histogram
 
toString() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.HistogramVisual
 
toString() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.last.DoubleLastAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.last.FloatLastAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.last.LongLastAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.last.StringLastAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
 
toString() - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
 
toString() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
 
toString() - Method in class org.apache.druid.query.BySegmentResultValueClass
 
toString() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
toString() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataResultValue
 
toString() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
toString() - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
toString() - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
toString() - Method in class org.apache.druid.query.dimension.PrefixFilteredDimensionSpec
 
toString() - Method in class org.apache.druid.query.dimension.RegexFilteredDimensionSpec
 
toString() - Method in class org.apache.druid.query.extraction.BucketExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.MatchingDimExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.RegexDimExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.SubstringDimExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
 
toString() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
 
toString() - Method in class org.apache.druid.query.filter.AndDimFilter
 
toString() - Method in class org.apache.druid.query.filter.BoundDimFilter
 
toString() - Method in class org.apache.druid.query.filter.ColumnComparisonDimFilter
 
toString() - Method in class org.apache.druid.query.filter.ExpressionDimFilter
 
toString() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
Deprecated.
 
toString() - Method in class org.apache.druid.query.filter.FalseDimFilter
 
toString() - Method in class org.apache.druid.query.filter.FilterTuning
 
toString() - Method in class org.apache.druid.query.filter.InDimFilter
 
toString() - Method in class org.apache.druid.query.filter.IntervalDimFilter
 
toString() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
 
toString() - Method in class org.apache.druid.query.filter.LikeDimFilter
 
toString() - Method in class org.apache.druid.query.filter.NotDimFilter
 
toString() - Method in class org.apache.druid.query.filter.OrDimFilter
 
toString() - Method in class org.apache.druid.query.filter.RegexDimFilter
 
toString() - Method in class org.apache.druid.query.filter.SearchQueryDimFilter
 
toString() - Method in class org.apache.druid.query.filter.SelectorDimFilter
 
toString() - Method in class org.apache.druid.query.filter.SpatialDimFilter
 
toString() - Method in class org.apache.druid.query.filter.TrueDimFilter
 
toString() - Method in class org.apache.druid.query.filter.vector.VectorMatch
 
toString() - Method in class org.apache.druid.query.GlobalTableDataSource
 
toString() - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
 
toString() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
 
toString() - Method in class org.apache.druid.query.groupby.epinephelinae.Grouper.Entry
 
toString() - Method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper.RowBasedKey
 
toString() - Method in class org.apache.druid.query.groupby.GroupByQuery
 
toString() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
toString() - Method in class org.apache.druid.query.groupby.having.AndHavingSpec
 
toString() - Method in class org.apache.druid.query.groupby.having.DimensionSelectorHavingSpec
 
toString() - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
 
toString() - Method in class org.apache.druid.query.groupby.having.EqualToHavingSpec
 
toString() - Method in class org.apache.druid.query.groupby.having.GreaterThanHavingSpec
 
toString() - Method in class org.apache.druid.query.groupby.having.LessThanHavingSpec
 
toString() - Method in class org.apache.druid.query.groupby.having.NotHavingSpec
 
toString() - Method in class org.apache.druid.query.groupby.having.OrHavingSpec
 
toString() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
 
toString() - Method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
 
toString() - Method in enum org.apache.druid.query.groupby.orderby.OrderByColumnSpec.Direction
 
toString() - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
 
toString() - Method in class org.apache.druid.query.groupby.ResultRow
 
toString() - Method in class org.apache.druid.query.InlineDataSource
 
toString() - Method in class org.apache.druid.query.JoinDataSource
 
toString() - Method in class org.apache.druid.query.lookup.LookupConfig
 
toString() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
 
toString() - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
 
toString() - Method in class org.apache.druid.query.lookup.LookupsState
 
toString() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
 
toString() - Method in class org.apache.druid.query.LookupDataSource
 
toString() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
 
toString() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
 
toString() - Method in enum org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
 
toString() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
toString() - Method in class org.apache.druid.query.MetricValueExtractor
 
toString() - Method in class org.apache.druid.query.ordering.StringComparators.AlphanumericComparator
 
toString() - Method in class org.apache.druid.query.ordering.StringComparators.LexicographicComparator
 
toString() - Method in class org.apache.druid.query.ordering.StringComparators.NumericComparator
 
toString() - Method in class org.apache.druid.query.ordering.StringComparators.StrlenComparator
 
toString() - Method in class org.apache.druid.query.ordering.StringComparators.VersionComparator
 
toString() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
 
toString() - Method in class org.apache.druid.query.planning.PreJoinableClause
 
toString() - Method in enum org.apache.druid.query.QueryContexts.Vectorize
 
toString() - Method in class org.apache.druid.query.QueryDataSource
 
toString() - Method in exception org.apache.druid.query.QueryInterruptedException
 
toString() - Method in class org.apache.druid.query.Result
 
toString() - Method in enum org.apache.druid.query.scan.ScanQuery.Order
 
toString() - Method in enum org.apache.druid.query.scan.ScanQuery.ResultFormat
 
toString() - Method in class org.apache.druid.query.scan.ScanQuery
 
toString() - Method in class org.apache.druid.query.scan.ScanQueryConfig
 
toString() - Method in class org.apache.druid.query.scan.ScanResultValue
 
toString() - Method in class org.apache.druid.query.search.AllSearchQuerySpec
 
toString() - Method in class org.apache.druid.query.search.BySegmentSearchResultValue
 
toString() - Method in class org.apache.druid.query.search.ContainsSearchQuerySpec
 
toString() - Method in class org.apache.druid.query.search.FragmentSearchQuerySpec
 
toString() - Method in class org.apache.druid.query.search.InsensitiveContainsSearchQuerySpec
 
toString() - Method in class org.apache.druid.query.search.RegexSearchQuerySpec
 
toString() - Method in class org.apache.druid.query.search.SearchHit
 
toString() - Method in class org.apache.druid.query.search.SearchQuery
 
toString() - Method in class org.apache.druid.query.search.SearchResultValue
 
toString() - Method in class org.apache.druid.query.search.SearchSortSpec
 
toString() - Method in class org.apache.druid.query.spec.MultipleIntervalSegmentSpec
 
toString() - Method in class org.apache.druid.query.spec.MultipleSpecificSegmentSpec
 
toString() - Method in class org.apache.druid.query.TableDataSource
 
toString() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
toString() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
 
toString() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
toString() - Method in class org.apache.druid.query.timeseries.TimeseriesResultValue
 
toString() - Method in class org.apache.druid.query.topn.AlphaNumericTopNMetricSpec
 
toString() - Method in class org.apache.druid.query.topn.BySegmentTopNResultValue
 
toString() - Method in class org.apache.druid.query.topn.DimensionAndMetricValueExtractor
 
toString() - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
toString() - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
toString() - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
toString() - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
toString() - Method in class org.apache.druid.query.topn.TopNQuery
 
toString() - Method in class org.apache.druid.query.topn.TopNResultValue
 
toString() - Method in class org.apache.druid.query.UnionDataSource
 
toString() - Method in class org.apache.druid.segment.AbstractIndex
 
toString() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
 
toString() - Method in class org.apache.druid.segment.column.RowSignature
 
toString() - Method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingStrategy
 
toString() - Method in enum org.apache.druid.segment.data.CompressionStrategy
 
toString() - Method in class org.apache.druid.segment.data.ConciseBitmapSerdeFactory
 
toString() - Method in class org.apache.druid.segment.data.GenericIndexed
 
toString() - Method in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
 
toString() - Method in class org.apache.druid.segment.filter.AndFilter
 
toString() - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
 
toString() - Method in class org.apache.druid.segment.filter.ExpressionFilter
 
toString() - Method in class org.apache.druid.segment.filter.FalseFilter
 
toString() - Method in class org.apache.druid.segment.filter.NotFilter
 
toString() - Method in class org.apache.druid.segment.filter.OrFilter
 
toString() - Method in class org.apache.druid.segment.filter.RegexFilter
 
toString() - Method in class org.apache.druid.segment.filter.SearchQueryFilter
 
toString() - Method in class org.apache.druid.segment.filter.SelectorFilter
 
toString() - Method in class org.apache.druid.segment.filter.TrueFilter
 
toString() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
 
toString() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
 
toString() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
 
toString() - Method in class org.apache.druid.segment.IndexSpec
 
toString() - Method in class org.apache.druid.segment.join.Equality
 
toString() - Method in class org.apache.druid.segment.join.filter.JoinFilterSplit
 
toString() - Method in class org.apache.druid.segment.join.JoinableClause
 
toString() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
 
toString() - Method in class org.apache.druid.segment.Metadata
 
toString() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.AscendingTimestampCheckingOffset
 
toString() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.DescendingTimestampCheckingOffset
 
toString() - Method in class org.apache.druid.segment.RowPointer
 
toString() - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
toString() - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
toString() - Method in class org.apache.druid.segment.TimeAndDimsPointer
 
toString() - Method in class org.apache.druid.segment.transform.ExpressionTransform
 
toString() - Method in class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
toString() - Method in class org.apache.druid.segment.transform.TransformSpec
 
toString() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
toString() - Method in class org.apache.druid.segment.VirtualColumns
 
toTransformer() - Method in class org.apache.druid.segment.transform.TransformSpec
Create a Transformer from this TransformSpec, when the rows to be transformed do not have a known signature.
toValue() - Method in enum org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
 
toYielder(OutType, YieldingAccumulator<OutType, ScanResultValue>) - Method in class org.apache.druid.query.scan.ScanQueryOffsetSequence
 
Transform - Interface in org.apache.druid.segment.transform
A row transform that is part of a TransformSpec.
transform(InputRow) - Method in class org.apache.druid.segment.transform.Transformer
Transforms an input row, or returns null if the row should be filtered out.
transform(InputRowListPlusRawValues) - Method in class org.apache.druid.segment.transform.Transformer
 
TransformableRowIterator - Interface in org.apache.druid.segment
TransformableRowIterator tightens RowIterator.getPointer() contract, that allows to transform iterated rows without allocations on each iterations, and reuse the mechanics of the underlying iterator.
TransformedInputRow(InputRow, Map<String, RowFunction>) - Constructor for class org.apache.druid.segment.transform.Transformer.TransformedInputRow
 
Transformer - Class in org.apache.druid.segment.transform
 
Transformer.TransformedInputRow - Class in org.apache.druid.segment.transform
 
TransformingInputEntityReader - Class in org.apache.druid.segment.transform
 
TransformingInputEntityReader(InputEntityReader, Transformer) - Constructor for class org.apache.druid.segment.transform.TransformingInputEntityReader
 
TransformingInputRowParser<T> - Class in org.apache.druid.segment.transform
 
TransformingInputRowParser(InputRowParser<T>, TransformSpec) - Constructor for class org.apache.druid.segment.transform.TransformingInputRowParser
 
TransformingInputSourceReader - Class in org.apache.druid.segment.transform
 
TransformingStringInputRowParser - Class in org.apache.druid.segment.transform
 
TransformingStringInputRowParser(ParseSpec, String, TransformSpec) - Constructor for class org.apache.druid.segment.transform.TransformingStringInputRowParser
 
TransformSpec - Class in org.apache.druid.segment.transform
Specifies how input rows should be filtered and transforms.
TransformSpec(DimFilter, List<Transform>) - Constructor for class org.apache.druid.segment.transform.TransformSpec
 
TrimExprMacro - Class in org.apache.druid.query.expression
 
TrimExprMacro(TrimExprMacro.TrimMode) - Constructor for class org.apache.druid.query.expression.TrimExprMacro
 
TrimExprMacro.BothTrimExprMacro - Class in org.apache.druid.query.expression
 
TrimExprMacro.LeftTrimExprMacro - Class in org.apache.druid.query.expression
 
TrimExprMacro.RightTrimExprMacro - Class in org.apache.druid.query.expression
 
TrueDimFilter - Class in org.apache.druid.query.filter
 
TrueFilter - Class in org.apache.druid.segment.filter
 
TrueVectorMatcher - Class in org.apache.druid.query.filter.vector
 
TrueVectorMatcher(VectorSizeInspector) - Constructor for class org.apache.druid.query.filter.vector.TrueVectorMatcher
 
TRUNCATED_RESPONSE_CONTEXT - Static variable in exception org.apache.druid.query.QueryInterruptedException
 
TruncatedResponseContextException - Exception in org.apache.druid.query
This exception is thrown when ResponseContext is truncated after serialization in historicals or realtime tasks.
TruncatedResponseContextException(String, Object...) - Constructor for exception org.apache.druid.query.TruncatedResponseContextException
 
TYPE - Static variable in class org.apache.druid.query.DruidMetrics
 

U

unapply(String) - Method in class org.apache.druid.query.extraction.MapLookupExtractor
 
unapply(String) - Method in class org.apache.druid.query.lookup.LookupExtractor
Provide the reverse mapping from a given value to a list of keys
unapplyAll(Iterable<String>) - Method in class org.apache.druid.query.lookup.LookupExtractor
 
UNAUTHORIZED - Static variable in exception org.apache.druid.query.QueryInterruptedException
 
UncompressedCompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.UncompressedCompressor
 
UncompressedDecompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.UncompressedDecompressor
 
union(Iterable<ImmutableBitmap>) - Method in interface org.apache.druid.collections.bitmap.BitmapFactory
Compute the union (bitwise-OR) of a set of bitmaps.
union(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.collections.bitmap.BitSetBitmapFactory
 
union(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.collections.bitmap.ConciseBitmapFactory
 
union(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
 
union(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
union(Iterable<T>) - Method in interface org.apache.druid.query.BitmapResultFactory
Delegates to BitmapFactory.union(Iterable) on the wrapped bitmaps, and returns a bitmap result wrapping the resulting union ImmutableBitmap.
union(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
UnionDataSource - Class in org.apache.druid.query
 
UnionDataSource(List<TableDataSource>) - Constructor for class org.apache.druid.query.UnionDataSource
 
unionDimensionValueBitmaps(Iterable<ImmutableBitmap>) - Method in interface org.apache.druid.query.BitmapResultFactory
Equivalent of intersection(Iterables.transform(dimensionValueBitmaps, factory::wrapDimensionValue)), but doesn't create a lot of bitmap result objects.
unionDimensionValueBitmaps(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
UnionQueryRunner<T> - Class in org.apache.druid.query
 
UnionQueryRunner(QueryRunner<T>) - Constructor for class org.apache.druid.query.UnionQueryRunner
 
UNKNOWN_EXCEPTION - Static variable in exception org.apache.druid.query.QueryInterruptedException
 
UnknownTypeComplexColumn - Class in org.apache.druid.segment.column
 
UnknownTypeComplexColumn() - Constructor for class org.apache.druid.segment.column.UnknownTypeComplexColumn
 
UNPARSEABLE - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
 
unprefix(String) - Method in class org.apache.druid.segment.join.JoinableClause
Removes our prefix from "columnName".
UNSUPPORTED_OPERATION - Static variable in exception org.apache.druid.query.QueryInterruptedException
 
update(double) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
update(DoubleMeanHolder) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
update(ByteBuffer, int, double) - Static method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
update(ByteBuffer, int, DoubleMeanHolder) - Static method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
 
updateDimValSelector(DimValSelector, int, int) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
updateDimValSelector(Aggregator[][], int, int) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
updateDimValSelector(int[], int, int) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
updateDimValSelector(int[], int, int) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
updateHeapIndexForOffset(int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper.BufferGrouperOffsetHeapIndexUpdater
 
updateResults(Parameters, DimValSelector, DimValAggregateStore, TopNResultBuilder) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
 
updateResults(TopNParams, Aggregator[][], TopNColumnAggregatesProcessor, TopNResultBuilder) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
 
updateResults(PooledTopNAlgorithm.PooledTopNParams, int[], BufferAggregator[], TopNResultBuilder) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
 
updateResults(TopNParams, int[], Map<Comparable<?>, Aggregator[]>, TopNResultBuilder) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
 
updateResults(TopNResultBuilder) - Method in class org.apache.druid.query.topn.types.NullableNumericTopNColumnAggregatesProcessor
 
updateResults(TopNResultBuilder) - Method in class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
 
updateResults(TopNResultBuilder) - Method in interface org.apache.druid.query.topn.types.TopNColumnAggregatesProcessor
updateSearchResultSet(String, BaseDoubleColumnValueSelector, SearchQuerySpec, int, Object2IntRBTreeMap<SearchHit>) - Method in class org.apache.druid.query.search.SearchQueryRunner.DoubleSearchColumnSelectorStrategy
 
updateSearchResultSet(String, BaseFloatColumnValueSelector, SearchQuerySpec, int, Object2IntRBTreeMap<SearchHit>) - Method in class org.apache.druid.query.search.SearchQueryRunner.FloatSearchColumnSelectorStrategy
 
updateSearchResultSet(String, BaseLongColumnValueSelector, SearchQuerySpec, int, Object2IntRBTreeMap<SearchHit>) - Method in class org.apache.druid.query.search.SearchQueryRunner.LongSearchColumnSelectorStrategy
 
updateSearchResultSet(String, ValueSelectorType, SearchQuerySpec, int, Object2IntRBTreeMap<SearchHit>) - Method in interface org.apache.druid.query.search.SearchQueryRunner.SearchColumnSelectorStrategy
Read the current row from dimSelector and update the search result set.
updateSearchResultSet(String, DimensionSelector, SearchQuerySpec, int, Object2IntRBTreeMap<SearchHit>) - Method in class org.apache.druid.query.search.SearchQueryRunner.StringSearchColumnSelectorStrategy
 
UpperExtractionFn - Class in org.apache.druid.query.extraction
 
UpperExtractionFn(String) - Constructor for class org.apache.druid.query.extraction.UpperExtractionFn
 
USE_CACHE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
USE_FILTER_CNF_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
UseIndexesStrategy - Class in org.apache.druid.query.search
 
UseIndexesStrategy.IndexOnlyExecutor - Class in org.apache.druid.query.search
 
useParallelMergePool() - Method in class org.apache.druid.query.DruidProcessingConfig
 
useParallelMergePoolConfigured() - Method in class org.apache.druid.query.DruidProcessingConfig
 
usesDotNotation() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
 
usesDotNotation() - Method in interface org.apache.druid.segment.VirtualColumn
Indicates that this virtual column can be referenced with dot notation.
usingDefaultInterval(boolean) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
 

V

V3CompressedVSizeColumnarMultiIntsSerializer - Class in org.apache.druid.segment.data
Streams array of integers out in the binary format described by V3CompressedVSizeColumnarMultiIntsSupplier
V3CompressedVSizeColumnarMultiIntsSupplier - Class in org.apache.druid.segment.data
The format is mostly the same with CompressedVSizeColumnarMultiIntsSupplier (which has version 0x2, so we call it V2), the only difference is V3's offsets is not VSize encoded, it's just compressed.
V8_VERSION - Static variable in class org.apache.druid.segment.IndexIO
 
V9_VERSION - Static variable in class org.apache.druid.segment.IndexIO
 
validateBufferCapacity(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
 
validatePrefix(String) - Static method in class org.apache.druid.segment.join.Joinables
Checks that "prefix" is a valid prefix for a join clause (see JoinableClause.getPrefix()) and, if so, returns it.
validateTwoSegments(File, File) - Method in class org.apache.druid.segment.IndexIO
 
validateTwoSegments(IndexableAdapter, IndexableAdapter) - Method in class org.apache.druid.segment.IndexIO
 
VALUE_COLUMN - Static variable in class org.apache.druid.segment.join.lookup.LookupColumnSelectorFactory
 
VALUE_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.first.DoubleFirstAggregatorFactory
 
VALUE_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.first.FloatFirstAggregatorFactory
 
VALUE_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.first.LongFirstAggregatorFactory
 
VALUE_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.first.StringFirstAggregatorFactory
 
ValueMatcher - Interface in org.apache.druid.query.filter
An object that returns a boolean indicating if the "current" row should be selected or not.
ValueMatchers - Class in org.apache.druid.segment.filter
Utility methods for creating ValueMatcher instances.
valueOf(String) - Static method in enum org.apache.druid.query.aggregation.post.ArithmeticPostAggregator.Ordering
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.aggregation.post.ExpressionPostAggregator.Ordering
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.context.ResponseContext.Key
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.extraction.ExtractionFn.ExtractionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.filter.LikeDimFilter.LikeMatcher.SuffixMatch
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.groupby.orderby.OrderByColumnSpec.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.QueryContexts.Vectorize
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.scan.ScanQuery.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.query.scan.ScanQuery.ResultFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.segment.data.CompressionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.segment.join.JoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.segment.MetricHolder.MetricType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.druid.segment.virtual.ExpressionPlan.Trait
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.druid.query.aggregation.post.ArithmeticPostAggregator.Ordering
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.aggregation.post.ExpressionPostAggregator.Ordering
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.context.ResponseContext.Key
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.extraction.ExtractionFn.ExtractionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.filter.LikeDimFilter.LikeMatcher.SuffixMatch
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.groupby.orderby.OrderByColumnSpec.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.QueryContexts.Vectorize
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.scan.ScanQuery.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.query.scan.ScanQuery.ResultFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.segment.data.CompressionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.segment.join.JoinType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.segment.MetricHolder.MetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.druid.segment.virtual.ExpressionPlan.Trait
Returns an array containing the constants of this enum type, in the order they are declared.
valueSize() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
Returns the size of values, in bytes.
ValueTypes - Class in org.apache.druid.segment.column
 
VARIANCE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
 
VARIANCE_STANDARD_DEVIATION - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
VECTOR_SIZE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
VectorAggregator - Interface in org.apache.druid.query.aggregation
An object that can aggregate metrics into a ByteBuffer, from vectorized column selectors.
VectorColumnProcessorFactory<T> - Interface in org.apache.druid.segment
Class that encapsulates knowledge about how to create vector column processors.
VectorColumnSelectorFactory - Interface in org.apache.druid.segment.vector
 
VectorCursor - Interface in org.apache.druid.segment.vector
Vectorized cursor used during query execution.
VectorCursorGranularizer - Class in org.apache.druid.query.vector
Class that helps vectorized query engines handle "granularity" parameters.
VectorGroupByEngine - Class in org.apache.druid.query.groupby.epinephelinae.vector
 
VectorGrouper - Interface in org.apache.druid.query.groupby.epinephelinae
Like a Grouper, but vectorized.
VECTORIZE_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
VECTORIZE_VIRTUAL_COLUMNS_KEY - Static variable in class org.apache.druid.query.QueryContexts
 
vectorized(boolean) - Method in class org.apache.druid.query.DefaultQueryMetrics
 
vectorized(boolean) - Method in interface org.apache.druid.query.QueryMetrics
Sets whether or not a segment scan has been vectorized.
vectorized(boolean) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
 
VectorMatch - Class in org.apache.druid.query.filter.vector
Implementation class for ReadableVectorMatch.
vectorObjectSelector(VectorSizeInspector, Object) - Static method in class org.apache.druid.segment.vector.ConstantVectorSelectors
 
VectorObjectSelector - Interface in org.apache.druid.segment.vector
Vectorized object selector, useful for complex columns.
VectorOffset - Interface in org.apache.druid.segment.vector
The movable version of ReadableVectorOffset.
vectorSelector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
Creates a VectorValueSelector for the aggregated column.
vectorSelector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
 
vectorSelector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
 
vectorSelector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
 
VectorSelectorUtils - Class in org.apache.druid.segment.vector
 
VectorSelectorUtils() - Constructor for class org.apache.druid.segment.vector.VectorSelectorUtils
 
VectorSizeInspector - Interface in org.apache.druid.segment.vector
Common interface for vectorized column selectors, matchers, etc, where callers are given the ability to inspect current and maximum vector sizes.
VectorValueMatcher - Interface in org.apache.druid.query.filter.vector
An object that returns a boolean indicating if the "current" row should be selected or not.
VectorValueMatcherColumnProcessorFactory - Class in org.apache.druid.query.filter.vector
 
VectorValueMatcherFactory - Interface in org.apache.druid.query.filter.vector
 
vectorValueSelector - Variable in class org.apache.druid.query.aggregation.any.NumericAnyVectorAggregator
 
vectorValueSelector(VectorSizeInspector, Number) - Static method in class org.apache.druid.segment.vector.ConstantVectorSelectors
 
VectorValueSelector - Interface in org.apache.druid.segment.vector
Vectorized selector for primitive columns.
verifyMaxQueryTimeout(Query<T>, long) - Static method in class org.apache.druid.query.QueryContexts
 
verifyPreconditions(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.DimensionTopNMetricSpec
 
verifyPreconditions(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
 
verifyPreconditions(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.LexicographicTopNMetricSpec
 
verifyPreconditions(List<AggregatorFactory>, List<PostAggregator>) - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
 
verifyPreconditions(List<AggregatorFactory>, List<PostAggregator>) - Method in interface org.apache.druid.query.topn.TopNMetricSpec
 
VERSION - Static variable in class org.apache.druid.query.ordering.StringComparators
 
VERSION - Static variable in class org.apache.druid.segment.data.CompressedColumnarDoublesSuppliers
 
VERSION - Static variable in class org.apache.druid.segment.data.CompressedColumnarFloatsSupplier
 
VERSION - Static variable in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
 
VERSION - Static variable in class org.apache.druid.segment.data.CompressedColumnarLongsSupplier
 
VERSION - Static variable in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
VERSION - Static variable in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
 
VERSION - Static variable in class org.apache.druid.segment.data.VSizeColumnarInts
 
version() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
 
version() - Method in interface org.apache.druid.segment.join.table.IndexedTable
Returns the version of this table, used to compare against when loading a new version of the table
version() - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
 
version() - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
 
VERSION_CACHE_ID - Static variable in class org.apache.druid.query.ordering.StringComparators
 
VERSION_NAME - Static variable in class org.apache.druid.query.ordering.StringComparators
 
VersionComparator() - Constructor for class org.apache.druid.query.ordering.StringComparators.VersionComparator
 
VirtualColumn - Interface in org.apache.druid.segment
Virtual columns are "views" created over a ColumnSelectorFactory or ColumnSelector.
VirtualColumnCacheHelper - Class in org.apache.druid.segment.virtual
 
virtualColumns(VirtualColumns) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
virtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
 
virtualColumns(VirtualColumns) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
virtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
 
virtualColumns(VirtualColumns) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
virtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
 
VirtualColumns - Class in org.apache.druid.segment
Class allowing lookup and usage of virtual columns.
VirtualizedColumnSelectorFactory - Class in org.apache.druid.segment.virtual
 
VirtualizedColumnSelectorFactory(ColumnSelectorFactory, VirtualColumns) - Constructor for class org.apache.druid.segment.virtual.VirtualizedColumnSelectorFactory
 
visit(Expr.Shuttle) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorDynamicExpr
 
visit(Expr.Shuttle) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
 
visit(String, HotLoopCallee) - Method in interface org.apache.druid.query.monomorphicprocessing.RuntimeShapeInspector
 
visit(String, Object) - Method in interface org.apache.druid.query.monomorphicprocessing.RuntimeShapeInspector
 
visit(String, T[]) - Method in interface org.apache.druid.query.monomorphicprocessing.RuntimeShapeInspector
 
visit(String, boolean) - Method in interface org.apache.druid.query.monomorphicprocessing.RuntimeShapeInspector
 
visit(String, String) - Method in interface org.apache.druid.query.monomorphicprocessing.RuntimeShapeInspector
To be called from HotLoopCallee.inspectRuntimeShape(RuntimeShapeInspector) with something, that is important to ensure monomorphism and predictable branch taking in hot loops, but doesn't apply to other visit() methods in RuntimeShapeInspector.
VSizeColumnarInts - Class in org.apache.druid.segment.data
 
VSizeColumnarInts(ByteBuffer, int) - Constructor for class org.apache.druid.segment.data.VSizeColumnarInts
 
VSizeColumnarIntsSerializer - Class in org.apache.druid.segment.data
Streams integers out in the binary format described by VSizeColumnarInts
VSizeColumnarIntsSerializer(SegmentWriteOutMedium, int) - Constructor for class org.apache.druid.segment.data.VSizeColumnarIntsSerializer
 
VSizeColumnarMultiInts - Class in org.apache.druid.segment.data
 
VSizeColumnarMultiIntsSerializer - Class in org.apache.druid.segment.data
Streams arrays of objects out in the binary format described by VSizeColumnarMultiInts.
VSizeColumnarMultiIntsSerializer(String, SegmentWriteOutMedium, int) - Constructor for class org.apache.druid.segment.data.VSizeColumnarMultiIntsSerializer
 
VSizeLongSerde - Class in org.apache.druid.segment.data
Currently only support big endian
VSizeLongSerde() - Constructor for class org.apache.druid.segment.data.VSizeLongSerde
 
VSizeLongSerde.LongDeserializer - Interface in org.apache.druid.segment.data
 
VSizeLongSerde.LongSerializer - Interface in org.apache.druid.segment.data
 

W

withAggregatorSizes(int[]) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
withAggregatorSpecs(List<AggregatorFactory>) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withAggregatorSpecs(List<AggregatorFactory>) - Method in class org.apache.druid.query.topn.TopNQuery
 
withArrayProvider(TopNMetricSpecBuilder<int[]>) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
withBaseDataSource(Query<T>, DataSource) - Static method in class org.apache.druid.query.Queries
Rewrite "query" to refer to some specific base datasource, instead of the one it currently refers to.
withBitmapIndex(GenericIndexedWriter<ImmutableBitmap>) - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
 
withBitmapSerdeFactory(BitmapSerdeFactory) - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
 
withBitmapSerdeFactory(BitmapSerdeFactory) - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2.SerializerBuilder
 
withBitmapSerdeFactory(BitmapSerdeFactory) - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2.SerializerBuilder
 
withBitmapSerdeFactory(BitmapSerdeFactory) - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2.SerializerBuilder
 
withByteOrder(ByteOrder) - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
 
withByteOrder(ByteOrder) - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde.SerializerBuilder
 
withByteOrder(ByteOrder) - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2.SerializerBuilder
 
withByteOrder(ByteOrder) - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde.SerializerBuilder
 
withByteOrder(ByteOrder) - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2.SerializerBuilder
 
withByteOrder(ByteOrder) - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde.SerializerBuilder
 
withByteOrder(ByteOrder) - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2.SerializerBuilder
 
withChildren(List<DataSource>) - Method in interface org.apache.druid.query.DataSource
Return a new DataSource, identical to this one, with different children.
withChildren(List<DataSource>) - Method in class org.apache.druid.query.InlineDataSource
 
withChildren(List<DataSource>) - Method in class org.apache.druid.query.JoinDataSource
 
withChildren(List<DataSource>) - Method in class org.apache.druid.query.LookupDataSource
 
withChildren(List<DataSource>) - Method in class org.apache.druid.query.QueryDataSource
 
withChildren(List<DataSource>) - Method in class org.apache.druid.query.TableDataSource
 
withChildren(List<DataSource>) - Method in class org.apache.druid.query.UnionDataSource
 
withColumns(ColumnIncluderator) - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
withCorrelations(JoinFilterCorrelations) - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
 
withCursor(Cursor) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
withDataSource(DataSource) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
withDataSource(DataSource) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withDataSource(DataSource) - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
withDataSource(DataSource) - Method in interface org.apache.druid.query.Query
 
withDataSource(DataSource) - Method in class org.apache.druid.query.scan.ScanQuery
 
withDataSource(DataSource) - Method in class org.apache.druid.query.search.SearchQuery
 
withDataSource(DataSource) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
withDataSource(DataSource) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
withDataSource(DataSource) - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
withDataSource(DataSource) - Method in class org.apache.druid.query.topn.TopNQuery
 
withDefaultSubQueryId() - Method in interface org.apache.druid.query.Query
 
withDefaultTimeout(Query<T>, long) - Static method in class org.apache.druid.query.QueryContexts
 
withDelegate(GenericColumnSerializer) - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde.SerializerBuilder
 
withDelegate(Serializer) - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde.SerializerBuilder
 
withDelegate(Serializer) - Method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2.SerializerBuilder
 
withDelegate(Serializer) - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde.SerializerBuilder
 
withDelegate(Serializer) - Method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2.SerializerBuilder
 
withDelegate(Serializer) - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde.SerializerBuilder
 
withDelegate(Serializer) - Method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2.SerializerBuilder
 
withDictionary(GenericIndexedWriter<String>) - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
 
withDimension(String) - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
 
withDimension(String) - Method in interface org.apache.druid.query.dimension.DimensionSpec
Returns a copy of this DimensionSpec with the underlying dimension (the value of DimensionSpec.getDimension()) replaced by "newDimension".
withDimension(String) - Method in class org.apache.druid.query.dimension.ExtractionDimensionSpec
 
withDimension(String) - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
 
withDimension(String) - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
 
withDimension(String) - Method in class org.apache.druid.query.dimension.PrefixFilteredDimensionSpec
 
withDimension(String) - Method in class org.apache.druid.query.dimension.RegexFilteredDimensionSpec
 
withDimensionSpec(DimensionSpec) - Method in class org.apache.druid.query.topn.TopNQuery
 
withDimensionSpecs(List<DimensionSpec>) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withDimensionsSpec(DimensionsSpec) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
withDimensionsSpec(InputRowParser) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
Deprecated.
withDimFilter(DimFilter) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withDimFilter(DimFilter) - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
withDimValIndex(Object) - Method in class org.apache.druid.query.topn.DimValHolder.Builder
 
withDimValue(Comparable, ValueType) - Method in class org.apache.druid.query.topn.DimValHolder.Builder
withFinalizedAnalysisTypes(SegmentMetadataQueryConfig) - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
withId(String) - Method in class org.apache.druid.query.BaseQuery
 
withId(String) - Method in interface org.apache.druid.query.Query
 
withId(String) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
withIdentity(String) - Method in class org.apache.druid.query.QueryPlus
Returns the same QueryPlus object with the identity replaced.
withinBounds() - Method in class org.apache.druid.segment.BitmapOffset
 
withinBounds() - Method in class org.apache.druid.segment.data.Offset
 
withinBounds() - Method in class org.apache.druid.segment.FilteredOffset
 
withinBounds() - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder.TimestampCheckingOffset
 
withinBounds() - Method in class org.apache.druid.segment.SimpleAscendingOffset
 
withinBounds() - Method in class org.apache.druid.segment.SimpleDescendingOffset
 
withLane(String) - Method in interface org.apache.druid.query.Query
 
withLimit(long) - Method in class org.apache.druid.query.scan.ScanQuery
 
withLimit(int) - Method in class org.apache.druid.query.search.SearchQuery
 
withLimitSpec(LimitSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withMaxQueuedBytes(long) - Method in class org.apache.druid.query.QueryPlus
Equivalent of withQuery(getQuery().withOverriddenContext(ImmutableMap.of(MAX_QUEUED_BYTES_KEY, maxQueuedBytes))).
withMaxScatterGatherBytes(Query<T>, long) - Static method in class org.apache.druid.query.QueryContexts
 
withMetrics(AggregatorFactory...) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
withMetricValues(Map<String, Object>) - Method in class org.apache.druid.query.topn.DimValHolder.Builder
 
withMinTimestamp(long) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
withNonNullLegacy(ScanQueryConfig) - Method in class org.apache.druid.query.scan.ScanQuery
 
withNormalizedBaseTableClauses(List<Filter>) - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
 
withNormalizedJoinTableClauses(List<Filter>) - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
 
withNumBytesPerRecord(int) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
withNumValuesPerPass(int) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
withOffset(long) - Method in class org.apache.druid.query.scan.ScanQuery
 
withOffsetToLimit() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
Returns a new DefaultLimitSpec identical to this one except for one difference: an offset parameter, if any, will be removed and added to the limit.
withoutThreadUnsafeState() - Method in class org.apache.druid.query.QueryPlus
Returns a QueryPlus object without the components which are unsafe for concurrent use from multiple threads, therefore couldn't be passed down in concurrent or async QueryRunners.
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
withOverriddenContext(Map<String, Object>) - Method in interface org.apache.druid.query.Query
 
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.scan.ScanQuery
 
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.search.SearchQuery
 
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
withOverriddenContext(Map<String, Object>) - Method in class org.apache.druid.query.topn.TopNQuery
 
withOverrides(GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
 
withOverrides(SearchQuery) - Method in class org.apache.druid.query.search.SearchQueryConfig
 
withParseSpec(ParseSpec) - Method in class org.apache.druid.segment.transform.TransformingInputRowParser
 
withParseSpec(ParseSpec) - Method in class org.apache.druid.segment.transform.TransformingStringInputRowParser
 
withPostAggregatorSpecs(List<PostAggregator>) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withPostAggregatorSpecs(List<PostAggregator>) - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
withPriority(int) - Method in interface org.apache.druid.query.Query
 
withQuery(Query<U>) - Method in class org.apache.druid.query.QueryPlus
Returns a QueryPlus object with QueryMetrics from this QueryPlus object, and the provided Query.
withQueryGranularity(Granularity) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
withQueryMetrics(QueryToolChest<T, ? extends Query<T>>) - Method in class org.apache.druid.query.QueryPlus
Returns the same QueryPlus object, if it already has QueryMetrics (QueryPlus.getQueryMetrics() returns not null), or returns a new QueryPlus object with Query from this QueryPlus and QueryMetrics created using the given QueryToolChest, via QueryToolChest.makeMetrics(Query) method.
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
 
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
 
withQuerySegmentSpec(QuerySegmentSpec) - Method in interface org.apache.druid.query.Query
Returns a new query, identical to this one, but with a different associated QuerySegmentSpec.
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.scan.ScanQuery
 
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.search.SearchQuery
 
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
 
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
 
withQuerySegmentSpec(QuerySegmentSpec) - Method in class org.apache.druid.query.topn.TopNQuery
 
withResultsBuf(ByteBuffer) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
withResultsBufHolder(ResourceHolder<ByteBuffer>) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
withRollup(boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
withSelectorPlus(ColumnSelectorPlus) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
 
withSpatialIndex(ByteBufferWriter<ImmutableRTree>) - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
 
withSpecificSegments(Query<T>, List<SegmentDescriptor>) - Static method in class org.apache.druid.query.Queries
Rewrite "query" to refer to some specific segment descriptors.
withSqlQueryId(String) - Method in class org.apache.druid.query.BaseQuery
 
withSqlQueryId(String) - Method in interface org.apache.druid.query.Query
 
withSubQueryId(String) - Method in class org.apache.druid.query.BaseQuery
 
withSubQueryId(String) - Method in interface org.apache.druid.query.Query
Returns a copy of this query with a new subQueryId (see Query.getSubQueryId().
withSubQueryId(String) - Method in class org.apache.druid.query.select.SelectQuery
Deprecated.
 
withSubtotalsSpec(List<List<String>>) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withThreshold(int) - Method in class org.apache.druid.query.topn.TopNQuery
 
withTimeout(Query<T>, long) - Static method in class org.apache.druid.query.QueryContexts
 
withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
withTopNMetricVal(Object) - Method in class org.apache.druid.query.topn.DimValHolder.Builder
 
withTypeName(String) - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde.SerializerBuilder
 
withValue(ColumnarIntsSerializer, boolean, boolean) - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
 
withVirtualColumns(VirtualColumns) - Method in class org.apache.druid.query.groupby.GroupByQuery
 
withVirtualColumns(VirtualColumns) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
 
withWaitMeasuredFromNow() - Method in class org.apache.druid.query.MetricsEmittingQueryRunner
 
wrap(MutableBitmap) - Static method in class org.apache.druid.collections.IntegerSet
 
wrap(int[]) - Static method in class org.apache.druid.query.filter.vector.VectorMatch
Creates a new match object with selectionSize = 0, and the provided array as a backing array.
wrap(Query<T>) - Static method in class org.apache.druid.query.QueryPlus
Returns the minimum bare QueryPlus object with the given query.
wrap(LookupExtractor) - Static method in class org.apache.druid.segment.join.lookup.LookupJoinable
 
wrap(Cursor, VirtualColumns, Filter) - Static method in class org.apache.druid.segment.join.PostJoinCursor
 
wrap(ColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
 
wrapAllFalse(ImmutableBitmap) - Method in interface org.apache.druid.query.BitmapResultFactory
Wraps a bitmap which is a result of BitmapFactory.makeEmptyImmutableBitmap() call.
wrapAllFalse(ImmutableBitmap) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
wrapAllTrue(ImmutableBitmap) - Method in interface org.apache.druid.query.BitmapResultFactory
Wraps a bitmap which is a result of BitmapFactory.complement(ImmutableBitmap, int) called with BitmapFactory.makeEmptyImmutableBitmap() as argument.
wrapAllTrue(ImmutableBitmap) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
wrapDimensionValue(ImmutableBitmap) - Method in interface org.apache.druid.query.BitmapResultFactory
Wraps a bitmap which designates rows in a segment with some specific dimension value.
wrapDimensionValue(ImmutableBitmap) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
 
wrapIfNeeded(Throwable) - Static method in exception org.apache.druid.query.QueryInterruptedException
 
WrappedBitSetBitmap - Class in org.apache.druid.collections.bitmap
WrappedBitSetBitmap implements MutableBitmap for java.util.BitSet
WrappedBitSetBitmap() - Constructor for class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
WrappedBitSetBitmap(BitSet) - Constructor for class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
WrappedBitSetBitmap(ByteBuffer) - Constructor for class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
 
WrappedConciseBitmap - Class in org.apache.druid.collections.bitmap
 
WrappedConciseBitmap() - Constructor for class org.apache.druid.collections.bitmap.WrappedConciseBitmap
Create a new WrappedConciseBitmap wrapping an empty ConciseSet
WrappedConciseBitmap(ConciseSet) - Constructor for class org.apache.druid.collections.bitmap.WrappedConciseBitmap
Create a bitmap wrapping the given bitmap
WrappedImmutableBitSetBitmap - Class in org.apache.druid.collections.bitmap
WrappedImmutableBitSetBitmap implements ImmutableBitmap for java.util.BitSet
WrappedImmutableBitSetBitmap(BitSet) - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
WrappedImmutableBitSetBitmap() - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
WrappedImmutableBitSetBitmap(ByteBuffer) - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
 
WrappedImmutableConciseBitmap - Class in org.apache.druid.collections.bitmap
 
WrappedImmutableConciseBitmap(IntBuffer) - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
 
WrappedImmutableConciseBitmap(ImmutableConciseSet) - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
Wrap an ImmutableConciseSet
WrappedImmutableRoaringBitmap - Class in org.apache.druid.collections.bitmap
 
WrappedImmutableRoaringBitmap(ByteBuffer) - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
 
WrappedImmutableRoaringBitmap(ImmutableRoaringBitmap) - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
Wrap an ImmutableRoaringBitmap
WrappedRoaringBitmap - Class in org.apache.druid.collections.bitmap
 
WrappedRoaringBitmap() - Constructor for class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
Creates a new WrappedRoaringBitmap wrapping an empty MutableRoaringBitmap
WrappedRoaringBitmap(boolean) - Constructor for class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
Creates a new WrappedRoaringBitmap wrapping an empty MutableRoaringBitmap
wrapRootGenerationSegment(Segment) - Static method in class org.apache.druid.segment.ReferenceCountingSegment
 
wrapSegment(Segment, ShardSpec) - Static method in class org.apache.druid.segment.ReferenceCountingSegment
 
WritableSupplier<T> - Interface in org.apache.druid.segment.data
 
write(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
 
write(byte[]) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
 
write(byte[], int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
 
write(T) - Method in class org.apache.druid.segment.data.ByteBufferWriter
 
write(long) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
 
write(long) - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
 
write(T) - Method in class org.apache.druid.segment.data.GenericIndexedWriter
 
write(long) - Method in class org.apache.druid.segment.data.LongsLongEncodingWriter
 
write(long) - Method in class org.apache.druid.segment.data.TableLongEncodingWriter
 
write(long) - Method in interface org.apache.druid.segment.data.VSizeLongSerde.LongSerializer
 
write(int) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
write(byte[]) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
write(byte[], int, int) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
write(ByteBuffer) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
writeAggregationRows(int[], int, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.Groupers
Write ints from "start" to "end" into "scratch", if start != 0.
writeByte(MetaSerdeHelper.ByteFieldWriter<T>) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
 
writeByteArray(Function<T, byte[]>) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
 
writeBytesNoPaddingTo(HeapByteBufferWriteOutBytes) - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
writeIndexes(List<IntBuffer>) - Method in interface org.apache.druid.segment.DimensionMerger
Internally construct any index structures relevant to this DimensionMerger.
writeIndexes(List<IntBuffer>) - Method in class org.apache.druid.segment.NumericDimensionMergerV9
 
writeIndexes(List<IntBuffer>) - Method in class org.apache.druid.segment.StringDimensionMergerV9
 
writeInt(MetaSerdeHelper.IntFieldWriter<T>) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
 
writeInt(int) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
writeInt(int) - Method in class org.apache.druid.segment.writeout.WriteOutBytes
Writes 4 bytes of the given value in big-endian order, i.
writeKeys(WritableMemory, int, int, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.DoubleGroupByVectorColumnSelector
 
writeKeys(WritableMemory, int, int, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.FloatGroupByVectorColumnSelector
 
writeKeys(WritableMemory, int, int, int, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnSelector
Write key parts for this column, from startRow (inclusive) to endRow (exclusive), into keySpace starting at keyOffset.
writeKeys(WritableMemory, int, int, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.LongGroupByVectorColumnSelector
 
writeKeys(WritableMemory, int, int, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableDoubleGroupByVectorColumnSelector
 
writeKeys(WritableMemory, int, int, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableFloatGroupByVectorColumnSelector
 
writeKeys(WritableMemory, int, int, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableLongGroupByVectorColumnSelector
 
writeKeys(WritableMemory, int, int, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.SingleValueStringGroupByVectorColumnSelector
 
writeKeyToResultRow(Memory, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.DoubleGroupByVectorColumnSelector
 
writeKeyToResultRow(Memory, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.FloatGroupByVectorColumnSelector
 
writeKeyToResultRow(Memory, int, ResultRow, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnSelector
Write key parts for this column into a particular result row.
writeKeyToResultRow(Memory, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.LongGroupByVectorColumnSelector
 
writeKeyToResultRow(Memory, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableDoubleGroupByVectorColumnSelector
 
writeKeyToResultRow(Memory, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableFloatGroupByVectorColumnSelector
 
writeKeyToResultRow(Memory, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableLongGroupByVectorColumnSelector
 
writeKeyToResultRow(Memory, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.SingleValueStringGroupByVectorColumnSelector
 
writeMergedValueDictionary(List<IndexableAdapter>) - Method in interface org.apache.druid.segment.DimensionMerger
Given a list of segment adapters: - Read _sorted order_ (e.
writeMergedValueDictionary(List<IndexableAdapter>) - Method in class org.apache.druid.segment.NumericDimensionMergerV9
 
writeMergedValueDictionary(List<IndexableAdapter>) - Method in class org.apache.druid.segment.StringDimensionMergerV9
 
WriteOutBytes - Class in org.apache.druid.segment.writeout
Appendable byte sequence for temporary storage.
WriteOutBytes() - Constructor for class org.apache.druid.segment.writeout.WriteOutBytes
 
writePair(ByteBuffer, int, SerializablePairLongString, int) - Static method in class org.apache.druid.query.aggregation.first.StringFirstLastUtils
 
writeSomething(MetaSerdeHelper.FieldWriter<T>) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
 
writeTo(WriteOutBytes) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.column.ColumnDescriptor
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarDoublesSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarFloatsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarLongsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.ByteBufferWriter
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.CompressedColumnarFloatsSupplier
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.CompressedColumnarIntsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.CompressedColumnarLongsSupplier
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarFloatsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarLongsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.GenericIndexed
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.GenericIndexedWriter
 
writeTo(ImmutableRTree, WriteOutBytes) - Method in class org.apache.druid.segment.data.ImmutableRTreeObjectStrategy
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.IntermediateColumnarLongsSerializer
 
writeTo(T, WriteOutBytes) - Method in interface org.apache.druid.segment.data.ObjectStrategy
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.VSizeColumnarInts
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.VSizeColumnarIntsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiIntsSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.DoubleColumnSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.DoubleColumnSerializerV2
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.FloatColumnSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.FloatColumnSerializerV2
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.LongColumnSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.LongColumnSerializerV2
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.serde.ComplexColumnSerializer
 
writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.serde.LargeColumnSupportedComplexColumnSerializer
 
writeTo(ByteBuffer, T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.ByteFieldWriter
 
writeTo(ByteBuffer, T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.FieldWriter
 
writeTo(ByteBuffer, T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.IntFieldWriter
 
writeTo(WritableByteChannel, T) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
 
writeTo(WritableByteChannel, FileSmoosher) - Method in interface org.apache.druid.segment.serde.Serializer
Writes serialized form of this object to the given channel.
writeTo(WritableByteChannel) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
 
writeTo(ByteBuffer) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
Takes all bytes that are written to this WriteOutBytes so far and writes them into the given ByteBuffer.
writeTo(WritableByteChannel) - Method in class org.apache.druid.segment.writeout.WriteOutBytes
Takes all bytes that are written to this WriteOutBytes so far and writes them into the given channel.
writeToKeyBuffer(int, Object, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.DoubleGroupByColumnSelectorStrategy
 
writeToKeyBuffer(int, Object, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FloatGroupByColumnSelectorStrategy
 
writeToKeyBuffer(int, Object, ByteBuffer) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
Write a given object to the keyBuffer at keyBufferPosition.
writeToKeyBuffer(int, Object, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.LongGroupByColumnSelectorStrategy
 
writeToKeyBuffer(int, Object, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.NullableNumericGroupByColumnSelectorStrategy
 
writeToKeyBuffer(int, Object, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.StringGroupByColumnSelectorStrategy
 

Z

ZERO_DOUBLE - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
 
ZERO_FLOAT - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
 
ZERO_LONG - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
 
ZeroIndexedInts - Class in org.apache.druid.segment.data
An IndexedInts that always returns a row containing a single zero.
ZTEST - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
 
A B C D E F G H I J K L M N O P Q R S T U V W Z 
Skip navigation links

Copyright © 2011–2021 The Apache Software Foundation. All rights reserved.