A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abort() - Method in class org.apache.druid.frame.file.FrameFileWriter
-
Stops writing this file and closes early.
- abs(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Abs() - Constructor for class org.apache.druid.math.expr.Function.Abs
- ABSENT_VALUE_ID - Static variable in class org.apache.druid.segment.ComparatorDimensionDictionary
- ABSENT_VALUE_ID - Static variable in class org.apache.druid.segment.DimensionDictionary
- 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
- AbstractFlatTextFormatParser - Class in org.apache.druid.java.util.common.parsers
- AbstractFlatTextFormatParser(String, boolean, int) - Constructor for class org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser
- AbstractFlatTextFormatParser.FlatTextFormat - Enum in org.apache.druid.java.util.common.parsers
- AbstractHttpClient - Class in org.apache.druid.java.util.http.client
- AbstractHttpClient() - Constructor for class org.apache.druid.java.util.http.client.AbstractHttpClient
- AbstractInputSource - Class in org.apache.druid.data.input
-
Abstract class for
InputSource
. - AbstractInputSource() - Constructor for class org.apache.druid.data.input.AbstractInputSource
- AbstractIntSet - Class in org.apache.druid.extendedset.intset
-
This class provides a skeletal implementation of the
IntSet
interface to minimize the effort required to implement this interface. - AbstractIntSet() - Constructor for class org.apache.druid.extendedset.intset.AbstractIntSet
- AbstractMonitor - Class in org.apache.druid.java.util.metrics
- AbstractMonitor() - Constructor for class org.apache.druid.java.util.metrics.AbstractMonitor
- AbstractOptimizableDimFilter - Class in org.apache.druid.query.filter
-
Base class for most
DimFilter
. - 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
- AbstractPrioritizedQueryRunnerCallable<T,V> - Class in org.apache.druid.query
-
A helper class to avoid boilerplate for creating
PrioritizedQueryRunnerCallable
objects. - AbstractPrioritizedQueryRunnerCallable(int, QueryRunner<V>) - Constructor for class org.apache.druid.query.AbstractPrioritizedQueryRunnerCallable
- 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.
- AbstractSerializableLongObjectPairSerde<T extends SerializablePair<Long,?>> - Class in org.apache.druid.query.aggregation
- AbstractSerializablePairLongObjectBufferStore<T extends SerializablePair<Long,?>> - Class in org.apache.druid.query.aggregation
- AbstractSerializablePairLongObjectBufferStore.TransferredBuffer - Class in org.apache.druid.query.aggregation
-
contains serialized data that is compressed and delta-encoded (Long) It's ready to be transferred to a
WritableByteChannel
- AbstractSerializablePairLongObjectColumnHeader<T extends SerializablePair<Long,?>> - Class in org.apache.druid.query.aggregation
- AbstractSerializablePairLongObjectColumnSerializer<T extends SerializablePair<Long,?>> - Class in org.apache.druid.query.aggregation
-
valid call sequence
- AbstractSerializablePairLongObjectDeltaEncodedStagedSerde<T extends SerializablePair<Long,?>> - Class in org.apache.druid.query.aggregation
-
serializes a Long/Object(Number) pair in the context of a column/segment.
- AbstractSerializablePairLongObjectSimpleStagedSerde<T extends SerializablePair<Long,?>> - Class in org.apache.druid.query.aggregation
-
serializes a Long/Object pair as Long:Byte:Object
- abuts(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- abuts(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.LinearPartitionChunk
- abuts(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- abuts(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- abuts(PartitionChunk<T>) - Method in interface org.apache.druid.timeline.partition.PartitionChunk
-
Determines if this PartitionChunk abuts another PartitionChunk.
- abuts(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- abuts(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- abuts(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- accept(Class<?>) - Method in class org.apache.druid.java.util.common.config.DurationCoercible
- 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
- accept(T, U, V) - Method in interface org.apache.druid.java.util.common.function.TriConsumer
-
Performs this operation on the given arguments.
- Accessor(ColumnType, int) - Constructor for class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- 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.
- accumulate(AccumulatedType, InType) - Method in interface org.apache.druid.java.util.common.guava.Accumulator
- accumulate(AccumulatedType, InType) - Method in class org.apache.druid.java.util.common.guava.YieldingAccumulator
- accumulate(ExprEval<?>) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorInputBindings
- accumulate(OutType, InType) - Method in class org.apache.druid.java.util.common.guava.MappingAccumulator
- accumulate(OutType, InType) - Method in class org.apache.druid.java.util.common.guava.MappingYieldingAccumulator
- accumulate(OutType, Accumulator<OutType, RowsAndColumns>) - Method in class org.apache.druid.query.operator.OperatorSequence
- accumulate(OutType, Accumulator<OutType, Out>) - Method in class org.apache.druid.java.util.common.guava.MappedSequence
- accumulate(OutType, Accumulator<OutType, T>) - Method in class org.apache.druid.common.guava.CombiningSequence
- accumulate(OutType, Accumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.BaseSequence
- accumulate(OutType, Accumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.ConcatSequence
- accumulate(OutType, Accumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.FilteredSequence
- accumulate(OutType, Accumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.LazySequence
- accumulate(OutType, Accumulator<OutType, T>) - Method in interface org.apache.druid.java.util.common.guava.Sequence
-
Accumulate this sequence using the given accumulator.
- accumulate(OutType, Accumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.YieldingSequenceBase
- accumulate(OutType, T) - Method in class org.apache.druid.java.util.common.guava.DelegatingYieldingAccumulator
- accumulate(OutType, T) - Method in class org.apache.druid.java.util.common.guava.FilteringAccumulator
- accumulate(OutType, T) - Method in class org.apache.druid.java.util.common.guava.FilteringYieldingAccumulator
- accumulateWithIndex(int, Object) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldLambdaBinding
- accumulateWithIndex(int, Object) - Method in class org.apache.druid.math.expr.ApplyFunction.FoldLambdaBinding
- accumulateWithIndex(int, Object) - Method in interface org.apache.druid.math.expr.ApplyFunction.IndexableFoldLambdaBinding
-
Update the index and accumulator value
- AccumulatingProcessorManager<T,R> - Class in org.apache.druid.frame.processor.manager
-
Processor manager that wraps another
ProcessorManager
and accumulates a result. - AccumulatingProcessorManager(ProcessorManager<T, ?>, R, BiFunction<R, T, R>) - Constructor for class org.apache.druid.frame.processor.manager.AccumulatingProcessorManager
- Accumulator<AccumulatedType,InType> - Interface in org.apache.druid.java.util.common.guava
- Accumulators - Class in org.apache.druid.java.util.common.guava
- Accumulators() - Constructor for class org.apache.druid.java.util.common.guava.Accumulators
- acos(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Acos() - Constructor for class org.apache.druid.math.expr.Function.Acos
- 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.FrameBasedIndexedTable
- 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
- acquireReferences() - Method in class org.apache.druid.segment.WrappedSegmentReference
- ACTIVE - org.apache.druid.metadata.TaskLookup.TaskLookupType
- adapters - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- add(byte[]) - Method in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- add(byte[]) - Method in class org.apache.druid.hll.HyperLogLogCollector
- add(byte[]) - Method in class org.apache.druid.java.util.http.client.io.AppendableByteArrayInputStream
- add(byte, ColumnType) - Static method in class org.apache.druid.segment.nested.FieldTypeInfo
- add(double) - Method in class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- add(double) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarDoublesSerializer
- add(double) - Method in interface org.apache.druid.segment.data.ColumnarDoublesSerializer
- add(double) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarDoublesSerializer
- add(float) - Method in class org.apache.druid.frame.write.columnar.FloatFrameMaker
- add(float) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarFloatsSerializer
- add(float) - Method in interface org.apache.druid.segment.data.ColumnarFloatsSerializer
- add(float) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarFloatsSerializer
- 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(int) - Method in class org.apache.druid.extendedset.intset.ConciseSet
- add(int) - Method in class org.apache.druid.extendedset.utilities.IntList
- add(int) - Method in class org.apache.druid.java.util.emitter.core.ConcurrentTimeCounter
- add(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferIntList
- add(int) - Method in class org.apache.druid.segment.nested.LocalDimensionDictionary
- add(long) - Method in class org.apache.druid.frame.write.columnar.LongFrameMaker
- add(long) - Method in class org.apache.druid.segment.data.BlockLayoutColumnarLongsSerializer
- add(long) - Method in interface org.apache.druid.segment.data.ColumnarLongsSerializer
- add(long) - Method in class org.apache.druid.segment.data.CompressedLongsSerializer
- add(long) - Method in class org.apache.druid.segment.data.EntireLayoutColumnarLongsSerializer
- add(long) - Method in class org.apache.druid.segment.data.IntermediateColumnarLongsSerializer
- add(short, byte) - Method in class org.apache.druid.hll.HyperLogLogCollector
- add(Key<? extends T>) - Method in class org.apache.druid.guice.ListProvider
- add(Module...) - Method in class org.apache.druid.guice.BaseInjectorBuilder
- add(E) - Method in class org.apache.druid.utils.CircularBuffer
- add(File) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher
- add(Class<? extends T>) - Method in class org.apache.druid.guice.ListProvider
- add(Integer) - Method in class org.apache.druid.collections.IntegerSet
- add(Object) - Method in class org.apache.druid.segment.join.table.RowBasedIndexBuilder
-
Add a key to the index.
- add(String) - Method in class org.apache.druid.query.filter.InDimFilter.ValuesSet
- add(String, double[]) - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns.Builder
- add(String, int[]) - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns.Builder
- add(String, File) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher
- add(String, Object[], ColumnType) - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns.Builder
- add(String, ByteBuffer) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher
- add(String, List<ByteBuffer>) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher
- add(String, Column) - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns.Builder
- add(String, ColumnType) - Method in class org.apache.druid.segment.column.RowSignature.Builder
-
Add a column to this signature.
- add(String, ColumnType, Object...) - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns.Builder
- 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
-
Adds a new row.
- add(ResponseContext.Key, 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(ColumnType) - Method in class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- add(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.PartitionHolder
- add(Interval, VersionType, PartitionChunk<ObjectType>) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- add(T) - Method in class org.apache.druid.collections.StableLimitingSorter
-
Offer an element to the sorter.
- add(T) - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
- add(T) - Method in class org.apache.druid.segment.DimensionDictionary
- addAggregator(AggregatorFactory) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- addAggregators(List<AggregatorFactory>, RowSignature.Finalization) - Method in class org.apache.druid.segment.column.RowSignature.Builder
-
Adds aggregations to a signature.
- addAll(Iterable<? extends Module>) - Method in class org.apache.druid.guice.BaseInjectorBuilder
- addAll(Collection<? extends Integer>) - Method in class org.apache.druid.collections.IntegerSet
- addAll(Collection<? extends String>) - Method in class org.apache.druid.query.filter.InDimFilter.ValuesSet
- addAll(Iterator<VersionedIntervalTimeline.PartitionChunkEntry<VersionType, ObjectType>>) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- addAll(List<Module>) - Method in class org.apache.druid.guice.BaseInjectorBuilder
- addAll(IntSet) - Method in class org.apache.druid.extendedset.intset.ConciseSet
- 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
- addArray(int[]) - Method in class org.apache.druid.collections.fastutil.DruidIntList
- addBinding(TypeLiteral<T>) - Method in class org.apache.druid.guice.ConditionalMultibind
-
Unconditionally bind target to the set.
- addBinding(Class<? extends T>) - Method in class org.apache.druid.guice.ConditionalMultibind
-
Unconditionally bind target to the set.
- addBinding(T) - Method in class org.apache.druid.guice.ConditionalMultibind
-
Unconditionally bind target to the set.
- addChild(Node) - Method in class org.apache.druid.collections.spatial.Node
- addChild(Node) - Method in class org.apache.druid.collections.spatial.Point
- addChunk(byte[]) - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
-
Adds a chunk of bytes.
- addChunk(byte[]) - Method in class org.apache.druid.java.util.http.client.response.BytesFullResponseHolder
- addChunk(byte[]) - Method in class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHolder
- addChunk(String) - Method in class org.apache.druid.java.util.http.client.response.StringFullResponseHolder
- addCloseableInstance(T) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a Closeable instance to the lifecycle at
Lifecycle.Stage.NORMAL
stage, doesn't try to call any "start" method on it, useLifecycle.addStartCloseInstance(Object)
instead if you need the latter behaviour. - addColumn(String, Column) - Method in class org.apache.druid.query.rowsandcols.AppendableMapOfColumns
- addColumn(String, Column) - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- addColumn(String, Column) - Method in interface org.apache.druid.query.rowsandcols.semantic.AppendableRowsAndColumns
-
Mutates the RowsAndColumns by appending the requested Column.
- addCommands(CliBuilder) - Method in interface org.apache.druid.cli.CliCommandCreator
- addCompactionStateToSegments(PartitionsSpec, DimensionsSpec, List<Object>, Map<String, Object>, Map<String, Object>, Map<String, Object>) - Static method in class org.apache.druid.timeline.CompactionState
- addConditionBinding(String, Predicate<String>, TypeLiteral<T>) - Method in class org.apache.druid.guice.ConditionalMultibind
-
Conditionally bind target to the set.
- addConditionBinding(String, Predicate<String>, Class<? extends T>) - Method in class org.apache.druid.guice.ConditionalMultibind
-
Conditionally bind target to the set.
- addConditionBinding(String, Predicate<String>, T) - Method in class org.apache.druid.guice.ConditionalMultibind
-
Conditionally bind target to the set.
- addConditionBinding(String, String, Predicate<String>, Class<? extends T>) - Method in class org.apache.druid.guice.ConditionalMultibind
- addCpuNanos(long) - Method in class org.apache.druid.query.context.ResponseContext
- addCredentials(Request) - Method in class org.apache.druid.java.util.http.client.auth.BasicCredentials
- addCredentials(Request) - Method in interface org.apache.druid.java.util.http.client.auth.Credentials
- addData(String, Object) - Method in class org.apache.druid.java.util.emitter.service.AlertBuilder
- addData(Map<String, Object>) - Method in class org.apache.druid.java.util.emitter.service.AlertBuilder
- addDefaults(Map<String, Object>, Map<String, Object>) - Static method in class org.apache.druid.query.QueryContexts
- 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
- addDimensionsToBuilder(ServiceMetricEvent.Builder, Map<String, String[]>) - Static method in class org.apache.druid.java.util.metrics.MonitorUtils
- addDirectoriesToMonitor(String[]) - Method in class org.apache.druid.java.util.metrics.SysMonitor
-
Deprecated.
- addDoubleArray(Object[]) - Method in class org.apache.druid.segment.nested.ValueDictionary
- addDoubleToCollector(HyperLogLogCollector, double) - Static method in class org.apache.druid.query.aggregation.cardinality.types.DoubleCardinalityAggregatorColumnSelectorStrategy
- addDoubleValue(Double) - Method in class org.apache.druid.segment.nested.ValueDictionary
- addEntry(Object, Object, Object[]) - Method in class org.apache.druid.query.topn.TopNLexicographicResultBuilder
- addEntry(Object, Object, Object[]) - Method in class org.apache.druid.query.topn.TopNNumericResultBuilder
- addEntry(Object, Object, Object[]) - Method in interface org.apache.druid.query.topn.TopNResultBuilder
- addEntry(DimensionAndMetricValueExtractor) - Method in class org.apache.druid.query.topn.TopNLexicographicResultBuilder
- addEntry(DimensionAndMetricValueExtractor) - Method in class org.apache.druid.query.topn.TopNNumericResultBuilder
- addEntry(DimensionAndMetricValueExtractor) - Method in interface org.apache.druid.query.topn.TopNResultBuilder
- addExprMacro(Binder, Class<? extends ExprMacroTable.ExprMacro>) - Static method in class org.apache.druid.guice.ExpressionModule
- addFile(File) - Method in class org.apache.druid.java.util.common.FileUtils.FileCopyResult
- addFiles(Collection<File>) - Method in class org.apache.druid.java.util.common.FileUtils.FileCopyResult
- addFilter(Filter) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- addFilter(Filter) - Method in interface org.apache.druid.query.rowsandcols.semantic.RowsAndColumnsDecorator
- addFloatToCollector(HyperLogLogCollector, float) - Static method in class org.apache.druid.query.aggregation.cardinality.types.FloatCardinalityAggregatorColumnSelectorStrategy
- addForwardMapping(int) - Method in class org.apache.druid.segment.IdMapping.Builder
-
Adds a lookup for the 'forwarded' index to the current highest index value.
- addHandler(Lifecycle.Handler) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a handler to the Lifecycle at the Stage.NORMAL stage.
- addHandler(Lifecycle.Handler, Lifecycle.Stage) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a handler to the Lifecycle.
- addHeader(String, String) - Method in class org.apache.druid.java.util.http.client.Request
- addHeaderValues(Multimap<String, String>) - Method in class org.apache.druid.java.util.http.client.Request
- addHeaderValues(String, Iterable<String>) - Method in class org.apache.druid.java.util.http.client.Request
- addLiteralField(ArrayList<NestedPathPart>, int) - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
- addLock(String, LockType) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Add a lock to the given entry
- addLog(String, LogType) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Add a log to the entry with the given id.
- addLongArray(Object[]) - Method in class org.apache.druid.segment.nested.ValueDictionary
- addLongToCollector(HyperLogLogCollector, long) - Static method in class org.apache.druid.query.aggregation.cardinality.types.LongCardinalityAggregatorColumnSelectorStrategy
- addLongValue(Long) - Method in class org.apache.druid.segment.nested.ValueDictionary
- addManagedInstance(T) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a "managed" instance (annotated with
LifecycleStart
andLifecycleStop
) to the Lifecycle at Stage.NORMAL. - addManagedInstance(T, Lifecycle.Stage) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a "managed" instance (annotated with
LifecycleStart
andLifecycleStop
) to the Lifecycle. - addMapping(int) - Method in class org.apache.druid.segment.IdMapping.Builder
-
Adds a lookup for the 'forwarded' index to the current highest index value, and a reverse lookup from this substitute index back to the original.
- addMaybeStartHandler(Lifecycle.Handler) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a handler to the Lifecycle at the Stage.NORMAL stage and starts it if the lifecycle has already been started.
- addMaybeStartHandler(Lifecycle.Handler, Lifecycle.Stage) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a handler to the Lifecycle and starts it if the lifecycle has already been started.
- addMaybeStartManagedInstance(T) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a "managed" instance (annotated with
LifecycleStart
andLifecycleStop
) to the Lifecycle at Stage.NORMAL and starts it if the lifecycle has already been started. - addMaybeStartManagedInstance(T, Lifecycle.Stage) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds a "managed" instance (annotated with
LifecycleStart
andLifecycleStop
) to the Lifecycle and starts it if the lifecycle has already been started. - addMaybeStartStartCloseInstance(T) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds an instance with a start() and/or close() method to the Lifecycle at Stage.NORMAL and starts it if the lifecycle has already been started.
- addMaybeStartStartCloseInstance(T, Lifecycle.Stage) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds an instance with a start() and/or close() method to the Lifecycle and starts it if the lifecycle has already been started.
- addMergedBatchesForLevel(int, long) - Method in class org.apache.druid.frame.processor.SuperSorterProgressTracker
-
This method is designed to be called during the course of the sorting.
- addMetric(String, Object) - Method in class org.apache.druid.query.timeseries.TimeseriesResultBuilder
- addMissingSegments(List<SegmentDescriptor>) - Method in class org.apache.druid.query.context.ResponseContext
- addMonitor(Monitor) - Method in class org.apache.druid.java.util.metrics.MonitorScheduler
- addNull() - Method in class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- addNull() - Method in class org.apache.druid.frame.write.columnar.FloatFrameMaker
- addNull() - Method in class org.apache.druid.frame.write.columnar.LongFrameMaker
- addNumeric(String, ExpressionType, VectorValueSelector) - Method in class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- addObjectSelector(String, ExpressionType, VectorObjectSelector) - Method in class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- 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
-
Adds post-aggregators to a signature.
- 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.
- addRemainingResponse(String, int) - Method in class org.apache.druid.query.context.ResponseContext
- addResource(Binder, Class<?>) - Static method in class org.apache.druid.guice.Jerseys
- addRowIngestionMetersTotals(RowIngestionMetersTotals) - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- addRowScanCount(long) - Method in class org.apache.druid.query.context.ResponseContext
- addSchema(SegmentId, SchemaPayloadPlus, String) - Method in class org.apache.druid.segment.SegmentSchemaMapping
-
Add schema information for the segment.
- addSegments(Iterator<DataSegment>) - Method in class org.apache.druid.timeline.SegmentTimeline
- addSelection() - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriter
- addSelection() - Method in class org.apache.druid.frame.write.columnar.ComplexFrameColumnWriter
- addSelection() - Method in class org.apache.druid.frame.write.columnar.DoubleFrameColumnWriter
- addSelection() - Method in class org.apache.druid.frame.write.columnar.FloatFrameColumnWriter
- addSelection() - Method in interface org.apache.druid.frame.write.columnar.FrameColumnWriter
-
Adds the current value to the writer
- addSelection() - Method in class org.apache.druid.frame.write.columnar.LongFrameColumnWriter
- addSelection() - Method in class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
- addSelection() - Method in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
- addSelection() - Method in interface org.apache.druid.frame.write.FrameWriter
-
Write the current row to the frame that is under construction, if there is enough space to do so.
- addSelection() - Method in class org.apache.druid.frame.write.RowBasedFrameWriter
- addSerde(ColumnPartSerde) - Method in class org.apache.druid.segment.column.ColumnDescriptor.Builder
- addShutdownCallback(Runnable) - Method in class org.apache.druid.common.config.Log4jShutdown
- addSize(int) - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
- addSizedFiles(Collection<File>) - Method in class org.apache.druid.java.util.common.FileUtils.FileCopyResult
- addStartCloseInstance(T) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds an instance with a start() and/or close() method to the Lifecycle at Stage.NORMAL.
- addStartCloseInstance(T, Lifecycle.Stage) - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
-
Adds an instance with a start() and/or close() method to the Lifecycle.
- addStreamToIndex(Stream<InputRow>, IncrementalIndex) - Static method in class org.apache.druid.segment.generator.DataGenerator
-
Add rows from any generator to an index.
- addStringArray(Object[]) - Method in class org.apache.druid.segment.nested.ValueDictionary
- addStringToCollector(HyperLogLogCollector, String) - Static method in class org.apache.druid.query.aggregation.cardinality.types.StringCardinalityAggregatorColumnSelectorStrategy
- addStringValue(String) - Method in class org.apache.druid.segment.nested.ValueDictionary
- AddSubExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.AddSubExprContext
- addThrowable(Throwable) - Method in class org.apache.druid.java.util.emitter.service.AlertBuilder
- addTimeColumn() - Method in class org.apache.druid.segment.column.RowSignature.Builder
- addToBitmapIndex(Node) - Method in class org.apache.druid.collections.spatial.Node
- addToFacts(IncrementalIndexRow, IncrementalIndex.InputRowHolder, boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- addToFacts(IncrementalIndexRow, IncrementalIndex.InputRowHolder, boolean) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
- addToIndex(IncrementalIndex, int) - Method in class org.apache.druid.segment.generator.DataGenerator
-
Add rows from this generator to an index.
- addToOffset(long) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- addUntypedArray() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
-
Set a flag when we encounter an empty array or array with only null elements
- addValue(byte[]) - Method in class org.apache.druid.segment.data.CompressedBlockSerializer
- addValue(byte[]) - Method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSerializer
- 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
- addValue(int, Object) - Method in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
-
Add a value to the unsorted local dictionary and write to an intermediate column
- addValue(ByteBuffer) - Method in class org.apache.druid.segment.data.CompressedBlockSerializer
- addValue(ByteBuffer) - Method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSerializer
- 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
- addVirtualColumns(VirtualColumns) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- addVirtualColumns(VirtualColumns) - Method in interface org.apache.druid.query.rowsandcols.semantic.RowsAndColumnsDecorator
- addWithSmooshedWriter(String, long) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher
- adjustCumulativeRowLength(int) - Static method in class org.apache.druid.frame.read.columnar.FrameColumnReaderUtils
-
Adjusts a negative cumulative row length from
FrameColumnReaderUtils.getCumulativeRowLength(Memory, long, int)
to be the actual positive length. - adjustDictionaryId(int) - Method in class org.apache.druid.segment.nested.VariantColumn.VariantVectorObjectSelector
- adjustedNumValues - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- adjustIndex - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- adjustTableWhenFull() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- ADMIN - org.apache.druid.error.DruidException.Persona
-
Represents an administrative user, a persona who is interacting with admin APIs and understands Druid query concepts without necessarily owning the infrastructure and operations of the cluster
- advance() - Method in class org.apache.druid.frame.segment.columnar.FrameVectorCursor
- advance() - Method in class org.apache.druid.frame.segment.FrameCursor
- 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.UnnestColumnValueSelectorCursor
- advance() - Method in class org.apache.druid.segment.UnnestDimensionCursor
- 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.
- advanceCursor(int) - Method in class org.apache.druid.frame.allocation.AppendableMemory
-
Advances the cursor a certain number of bytes.
- 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.BatchIteratorAdapter
- advanceIfNeeded(int) - Method in class org.apache.druid.collections.bitmap.ConcisePeekableIteratorAdapter
- advanceIfNeeded(int) - Method in class org.apache.druid.collections.bitmap.PeekableIteratorAdapter
- advanceTo(int) - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet.WordIterator
- advanceUninterruptibly() - Method in class org.apache.druid.frame.segment.FrameCursor
- 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
- advanceUninterruptibly() - Method in class org.apache.druid.segment.UnnestColumnValueSelectorCursor
- advanceUninterruptibly() - Method in class org.apache.druid.segment.UnnestDimensionCursor
- after(boolean, Throwable) - Method in class org.apache.druid.java.util.common.guava.SequenceWrapper
-
Executed after sequence processing, i.
- 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
-
Performs aggregation.
- aggregate() - Method in class org.apache.druid.query.aggregation.any.NumericAnyAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.constant.LongConstantAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.CountAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.firstlast.first.NumericFirstAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.firstlast.last.NumericLastAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.FloatMinAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.FloatSumAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.HistogramAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.LongMaxAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.LongMinAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.LongSumAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.NoopAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.SingleValueAggregator
- aggregate() - Method in class org.apache.druid.query.aggregation.StringColumnDoubleAggregatorWrapper
- aggregate() - Method in class org.apache.druid.query.aggregation.StringColumnFloatAggregatorWrapper
- aggregate() - Method in class org.apache.druid.query.aggregation.StringColumnLongAggregatorWrapper
- aggregate() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
- aggregate(int) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.NumericAnyBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.NumericFirstBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.NumericLastBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMaxBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMinBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongSumBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SingleValueBufferAggregator
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.StringColumnDoubleBufferAggregatorWrapper
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.StringColumnFloatBufferAggregatorWrapper
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.StringColumnLongBufferAggregatorWrapper
- aggregate(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
- aggregate(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleMaxBufferAggregator
- aggregate(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleMinBufferAggregator
- aggregate(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.DoubleSumBufferAggregator
- aggregate(ByteBuffer, int, double) - Method in class org.apache.druid.query.aggregation.SimpleDoubleBufferAggregator
- aggregate(ByteBuffer, int, float) - Method in class org.apache.druid.query.aggregation.FloatMaxBufferAggregator
- aggregate(ByteBuffer, int, float) - Method in class org.apache.druid.query.aggregation.FloatMinBufferAggregator
- aggregate(ByteBuffer, int, float) - Method in class org.apache.druid.query.aggregation.FloatSumBufferAggregator
- aggregate(ByteBuffer, int, float) - Method in class org.apache.druid.query.aggregation.SimpleFloatBufferAggregator
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.any.NilVectorAggregator
- aggregate(ByteBuffer, int, 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.StringAnyVectorAggregator
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityVectorAggregator
- aggregate(ByteBuffer, int, int[], int[], int) - Method in interface org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessor
-
Processor for
VectorAggregator.aggregate(ByteBuffer, int, int, int)
in byRow = false mode. - aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.DoubleCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.FloatCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.LongCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.MultiValueStringCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.SingleValueStringCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.StringObjectCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantVectorAggregator
- aggregate(ByteBuffer, int, 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.DoubleMaxVectorAggregator
- aggregate(ByteBuffer, int, 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.DoubleSumVectorAggregator
- aggregate(ByteBuffer, int, 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.firstlast.FirstLastVectorAggregator
- aggregate(ByteBuffer, int, 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.FloatMinVectorAggregator
- aggregate(ByteBuffer, int, 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.hyperloglog.HyperUniquesVectorAggregator
- aggregate(ByteBuffer, int, 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.LongMinVectorAggregator
- aggregate(ByteBuffer, int, 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.mean.DoubleMeanVectorAggregator
- aggregate(ByteBuffer, int, 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.NullableNumericVectorAggregator
- aggregate(ByteBuffer, int, int[], int[], int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedVectorAggregator
- 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(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.any.NilVectorAggregator
- aggregate(ByteBuffer, 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.StringAnyVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in interface org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessor
-
Processor for
VectorAggregator.aggregate(ByteBuffer, int, int, int)
in byRow = false mode. - aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.DoubleCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.FloatCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.LongCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.MultiValueStringCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.SingleValueStringCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.cardinality.vector.StringObjectCardinalityVectorProcessor
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.CountVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.DoubleMaxVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.DoubleMinVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.DoubleSumVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.FilteredVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.FloatMaxVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.FloatMinVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.FloatSumVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.LongMaxVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.LongMinVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.LongSumVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.NoopVectorAggregator
- aggregate(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.NullableNumericVectorAggregator
- aggregate(ByteBuffer, 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(KeyType) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper
-
Aggregate the current row with the provided key.
- aggregate(KeyType) - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
- 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, 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(IntKey) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper
-
Deprecated.Please use
IntGrouper.aggregate(int)
instead. - aggregate(IntKey, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper
-
Deprecated.Please use
IntGrouper.aggregateKeyHash(int)
instead. - aggregateAll(WindowFrame, AggregatorFactory[]) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultFramedOnHeapAggregatable
- aggregateAll(WindowFrame, AggregatorFactory[]) - Method in interface org.apache.druid.query.rowsandcols.semantic.FramedOnHeapAggregatable
-
Aggregates the data according to the
WindowFrame
using theAggregatorFactory
objects provided. - 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
-
Call
VectorAggregator.aggregate(ByteBuffer, int, int[], int[], int)
on all of our aggregators. - aggregateVector(ByteBuffer, int, int, int) - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
-
Call
VectorAggregator.aggregate(ByteBuffer, int, int, int)
on all of our aggregators. - 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.
- aggregateWithSize() - Method in interface org.apache.druid.query.aggregation.Aggregator
-
Performs aggregation and returns the increase in required on-heap memory caused by this aggregation step.
- 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.
- AggregatorAndSize - Class in org.apache.druid.query.aggregation
-
Encapsulates an
Aggregator
and the initial size in bytes required by the Aggregator. - AggregatorAndSize(Aggregator, long) - Constructor for class org.apache.druid.query.aggregation.AggregatorAndSize
- 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
- aggregatorMergeStrategy(AggregatorMergeStrategy) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- AggregatorMergeStrategy - Enum in org.apache.druid.query.metadata.metadata
- 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 - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- aggregators(List<? extends AggregatorFactory>) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- aggregators(List<AggregatorFactory>) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- aggregators(AggregatorFactory...) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- aggregators(AggregatorFactory...) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- AGGREGATORS - org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
- 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
- AlertBuilder - Class in org.apache.druid.java.util.emitter.service
- AlertBuilder(String, ServiceEmitter) - Constructor for class org.apache.druid.java.util.emitter.service.AlertBuilder
- AlertEvent - Class in org.apache.druid.java.util.emitter.service
- AlertEvent(String, String, String) - Constructor for class org.apache.druid.java.util.emitter.service.AlertEvent
- AlertEvent(String, String, String, Map<String, Object>) - Constructor for class org.apache.druid.java.util.emitter.service.AlertEvent
- AlertEvent(String, String, AlertEvent.Severity, String, Map<String, Object>) - Constructor for class org.apache.druid.java.util.emitter.service.AlertEvent
- AlertEvent(DateTime, ImmutableMap<String, String>, AlertEvent.Severity, String, Map<String, Object>) - Constructor for class org.apache.druid.java.util.emitter.service.AlertEvent
- AlertEvent(DateTime, String, String, AlertEvent.Severity, String, Map<String, Object>) - Constructor for class org.apache.druid.java.util.emitter.service.AlertEvent
- AlertEvent.Severity - Enum in org.apache.druid.java.util.emitter.service
- algorithm(TopNAlgorithm) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
- algorithm(TopNAlgorithm) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
- ALIAS - Static variable in class org.apache.druid.math.expr.BuiltInExprMacros.ComplexDecodeBase64ExprMacro
- all() - Static method in class org.apache.druid.data.input.ColumnsFilter
-
Accepts all columns.
- ALL - org.apache.druid.java.util.common.granularity.GranularityType
- ALL - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- ALL_FALSE - org.apache.druid.segment.filter.ConstantMatcherType
-
Constant matcher that is always false
- ALL_FALSE - Static variable in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- ALL_ONES_LITERAL - Static variable in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Literal that represents all bits set to 1 (and MSB = 1)
- ALL_ONES_WITHOUT_MSB - Static variable in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
All bits set to 1 and MSB = 0
- ALL_TRUE - org.apache.druid.segment.filter.ConstantMatcherType
-
Constant matcher that is always true
- ALL_UNKNOWN - org.apache.druid.segment.filter.ConstantMatcherType
-
Constant matcher that is always null
- ALL_ZEROS_LITERAL - Static variable in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Literal that represents all bits set to 0 (and MSB = 1)
- allAbutting() - Method in class org.apache.druid.frame.key.ClusterByPartitions
-
Whether this list of partitions is all abutting, meaning: each partition's start is equal to the previous partition's end.
- 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() - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Matcher for constant 'false' condition, where rows will never be matched
- allFalse(long, ImmutableBitmap) - Static method in class org.apache.druid.query.filter.FilterBundle
- AllFalseBitmapColumnIndex - Class in org.apache.druid.segment.index
- AllFalseBitmapColumnIndex(BitmapFactory) - Constructor for class org.apache.druid.segment.index.AllFalseBitmapColumnIndex
- AllFalseBitmapColumnIndex(BitmapFactory, ImmutableBitmap) - Constructor for class org.apache.druid.segment.index.AllFalseBitmapColumnIndex
- allFalseMultiValueDimensionMatcher(MultiValueDimensionVectorSelector) - Static method in interface org.apache.druid.query.filter.vector.VectorValueMatcher
-
Make an always false
VectorValueMatcher
for aMultiValueDimensionVectorSelector
. - allFalseObjectMatcher(VectorObjectSelector) - Static method in interface org.apache.druid.query.filter.vector.VectorValueMatcher
-
Make an always false
VectorValueMatcher
for aVectorObjectSelector
. - allFalseSingleValueDimensionMatcher(SingleValueDimensionVectorSelector) - Static method in interface org.apache.druid.query.filter.vector.VectorValueMatcher
-
Make an always false
VectorValueMatcher
for aSingleValueDimensionVectorSelector
. - allFalseValueMatcher(VectorValueSelector) - Static method in interface org.apache.druid.query.filter.vector.VectorValueMatcher
-
Make an always false
VectorValueMatcher
for aVectorValueSelector
. - AllGranularity - Class in org.apache.druid.java.util.common.granularity
-
AllGranularty buckets everything into a single bucket
- AllGranularity() - Constructor for class org.apache.druid.java.util.common.granularity.AllGranularity
-
This constructor is public b/c it is serialized and deserialized based on type in GranularityModule
- AllMatchFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.AllMatchFunction
- allNull() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- AllNullColumnSelectorFactory - Class in org.apache.druid.segment.join.filter
- AllNullColumnSelectorFactory() - Constructor for class org.apache.druid.segment.join.filter.AllNullColumnSelectorFactory
- allocate(long) - Method in class org.apache.druid.frame.allocation.ArenaMemoryAllocator
- allocate(long) - Method in class org.apache.druid.frame.allocation.HeapMemoryAllocator
- allocate(long) - Method in interface org.apache.druid.frame.allocation.MemoryAllocator
-
Allocates a block of memory of capacity {@param size}.
- allocateBuffer() - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
- allocateBuffer() - Method in class org.apache.druid.segment.writeout.HeapByteBufferWriteOutBytes
- allocateDirect(int) - Static method in class org.apache.druid.java.util.common.ByteBufferUtils
-
Same as
ByteBuffer.allocateDirect(int)
, but returns a closeableResourceHolder
that frees the buffer upon close. - allocateInBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.Compressor
-
Allocates a buffer that should be passed to
CompressionStrategy.Compressor.compress(java.nio.ByteBuffer, java.nio.ByteBuffer)
method as input buffer. - allocateInBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.LZ4Compressor
- allocateInBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.ZstdCompressor
- allocateOutBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.Compressor
-
Allocates a buffer that should be passed to
CompressionStrategy.Compressor.compress(java.nio.ByteBuffer, java.nio.ByteBuffer)
method as output buffer. - allocateOutBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.LZ4Compressor
- allocateOutBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.LZFCompressor
- allocateOutBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.UncompressedCompressor
- allocateOutBuffer(int, Closer) - Method in class org.apache.druid.segment.data.CompressionStrategy.ZstdCompressor
- allocatorCapacity() - Method in class org.apache.druid.frame.allocation.ArenaMemoryAllocatorFactory
- allocatorCapacity() - Method in interface org.apache.druid.frame.allocation.MemoryAllocatorFactory
-
Capacity of allocators returned by
MemoryAllocatorFactory.newAllocator()
. - allocatorCapacity() - Method in class org.apache.druid.frame.allocation.SingleMemoryAllocatorFactory
- allocatorCapacity() - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriterFactory
- allocatorCapacity() - Method in interface org.apache.druid.frame.write.FrameWriterFactory
- allocatorCapacity() - Method in class org.apache.druid.frame.write.RowBasedFrameWriterFactory
- AllowedRegexErrorResponseTransformStrategy - Class in org.apache.druid.common.exception
- AllowedRegexErrorResponseTransformStrategy(List<String>) - Constructor for class org.apache.druid.common.exception.AllowedRegexErrorResponseTransformStrategy
- allowReturnPartialResults(boolean) - Method in class org.apache.druid.query.QueryContext
- allowReverseLookup - Variable in class org.apache.druid.segment.data.GenericIndexed
- AllSearchQuerySpec - Class in org.apache.druid.query.search
- AllSearchQuerySpec() - Constructor for class org.apache.druid.query.search.AllSearchQuerySpec
- allTrue() - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Matcher for constant 'true' condition, where all rows should always match
- allTrue(int) - Static method in class org.apache.druid.query.filter.vector.VectorMatch
-
Creates a match that matches everything up to "numRows".
- AllTrueBitmapColumnIndex - Class in org.apache.druid.segment.index
- AllTrueBitmapColumnIndex(ColumnIndexSelector) - Constructor for class org.apache.druid.segment.index.AllTrueBitmapColumnIndex
- allUnknown() - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Matcher for constant 'unknown' condition, such as a column of all null values, where rows will never match unless
includeUnknown
is set to true on the match function. - AllUnknownBitmapColumnIndex - Class in org.apache.druid.segment.index
-
Like
AllFalseBitmapColumnIndex
during normal operation, except if called with 'includeUnknowns' becomes likeAllTrueBitmapColumnIndex
. - AllUnknownBitmapColumnIndex(ColumnIndexSelector) - Constructor for class org.apache.druid.segment.index.AllUnknownBitmapColumnIndex
- 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_WITH_NULL_UNKNOWN - Static variable in interface org.apache.druid.query.filter.DruidDoublePredicate
- ALWAYS_FALSE_WITH_NULL_UNKNOWN - Static variable in interface org.apache.druid.query.filter.DruidFloatPredicate
- ALWAYS_FALSE_WITH_NULL_UNKNOWN - 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.DruidFloatPredicate
- ALWAYS_TRUE - Static variable in interface org.apache.druid.query.filter.DruidLongPredicate
- alwaysEqual() - Static method in class org.apache.druid.java.util.common.guava.Comparators
- alwaysFalseWithNullUnknown() - Static method in interface org.apache.druid.query.filter.DruidObjectPredicate
- 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
- alwaysTrue() - Static method in interface org.apache.druid.query.filter.DruidObjectPredicate
- analysisTypes(EnumSet<SegmentMetadataQuery.AnalysisType>) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- analysisTypes(SegmentMetadataQuery.AnalysisType...) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- analyze(Segment) - Method in class org.apache.druid.query.metadata.SegmentAnalyzer
- analyzeBindings(List<Expr>) - Static method in class org.apache.druid.math.expr.Exprs
-
Return a
Expr.BindingAnalysis
that represents an analysis of all provided args. - analyzeInputs() - Method in interface org.apache.druid.math.expr.Expr
- analyzeInputs() - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- 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(List<DimFilter>) - Static method in class org.apache.druid.query.filter.DimFilters
- 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.
- and(MutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
- and(Monitor...) - Static method in class org.apache.druid.java.util.metrics.Monitors
- and(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Creates an
ExprVectorProcessor
for the logical 'and' operator, which produces a long typed vector output with values set by the following rules: true/true -> true (1) true/null, null/true, null/null -> null false/null, null/false -> false (0) - and(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 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- AND - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- AND_JOINER - Static variable in class org.apache.druid.segment.filter.AndFilter
- 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
-
Logical AND filter operation
- AndFilter(LinkedHashSet<Filter>) - Constructor for class org.apache.druid.segment.filter.AndFilter
- AndFilter(List<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
- andThen(TriConsumer<? super T, ? super U, ? super V>) - Method in interface org.apache.druid.java.util.common.function.TriConsumer
-
Returns a composed
TriConsumer
that performs, in sequence, this operation followed by theafter
operation. - ANNOUNCEMENTS - org.apache.druid.java.util.common.lifecycle.Lifecycle.Stage
- ANOMALY - org.apache.druid.java.util.emitter.service.AlertEvent.Severity
- any(ExpressionPlan.Trait...) - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
Returns true if any of the supplied traits are true in this plan
- AnyMatchFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.AnyMatchFunction
- anyOf(Type...) - Method in interface org.apache.druid.segment.column.TypeSignature
-
Check if the value of
TypeSignature.getType()
matches any of theTypeDescriptor
specified. - append(T) - Method in class org.apache.druid.query.filter.DimFilter.DimFilterToStringBuilder
-
Generic passthrough to
StringBuilder.append(java.lang.Object)
- AppendableByteArrayInputStream - Class in org.apache.druid.java.util.http.client.io
- AppendableByteArrayInputStream() - Constructor for class org.apache.druid.java.util.http.client.io.AppendableByteArrayInputStream
- AppendableIndexBuilder - Class in org.apache.druid.segment.incremental
- AppendableIndexBuilder() - Constructor for class org.apache.druid.segment.incremental.AppendableIndexBuilder
- AppendableIndexModule - Class in org.apache.druid.jackson
- AppendableIndexModule() - Constructor for class org.apache.druid.jackson.AppendableIndexModule
- AppendableIndexModule.AppendableIndexSpecMixin - Interface in org.apache.druid.jackson
- AppendableIndexSpec - Interface in org.apache.druid.segment.incremental
-
AppendableIndexSpec describes the in-memory indexing method for data ingestion.
- AppendableMapOfColumns - Class in org.apache.druid.query.rowsandcols
- AppendableMapOfColumns(RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.AppendableMapOfColumns
- AppendableMemory - Class in org.apache.druid.frame.allocation
-
A class that allows writing to a series of Memory blocks as if they are one big coherent chunk of memory.
- AppendableRowsAndColumns - Interface in org.apache.druid.query.rowsandcols.semantic
-
A RowsAndColumns that supports appending columns.
- 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.
- appendDimension(String, ExtractionFn) - Method in class org.apache.druid.query.filter.DimFilter.DimFilterToStringBuilder
-
Append dimension name OR
ExtractionFn#toString()
with dimension wrapped in parenthesis - appendDouble(double) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
- appendDoubleArray(double[]) - Method in class org.apache.druid.query.cache.CacheKeyBuilder
- appendEquals(String) - Method in class org.apache.druid.query.filter.DimFilter.DimFilterToStringBuilder
-
Add "=" expression
- appendFilterTuning(FilterTuning) - Method in class org.apache.druid.query.filter.DimFilter.DimFilterToStringBuilder
-
Add filter tuning to
DimFilter.DimFilterToStringBuilder.builder
if tuning exists - 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
- appendLong(long) - 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(double) - Method in class org.apache.druid.math.expr.vector.DoubleOutDoubleInFunctionVectorValueProcessor
- apply(double) - Method in class org.apache.druid.math.expr.vector.LongOutDoubleInFunctionVectorValueProcessor
- apply(double, double) - Method in class org.apache.druid.math.expr.vector.DoubleOutDoublesInFunctionVectorValueProcessor
- apply(double, double) - Method in class org.apache.druid.math.expr.vector.LongOutDoublesInFunctionVectorValueProcessor
- apply(double, long) - Method in class org.apache.druid.math.expr.vector.DoubleOutDoubleLongInFunctionVectorValueProcessor
- apply(double, long) - Method in class org.apache.druid.math.expr.vector.LongOutDoubleLongInFunctionVectorValueProcessor
- apply(int) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper.IntGrouperHashFunction
- apply(long) - Method in class org.apache.druid.math.expr.vector.DoubleOutLongInFunctionVectorValueProcessor
- apply(long) - Method in class org.apache.druid.math.expr.vector.LongOutLongInFunctionVectorValueProcessor
- apply(long) - Method in class org.apache.druid.query.extraction.BucketExtractionFn
- apply(long) - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
- apply(long) - Method in class org.apache.druid.query.extraction.DimExtractionFn
- apply(long) - Method in interface org.apache.druid.query.extraction.ExtractionFn
-
The "extraction" function.
- apply(long) - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
- apply(long) - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
- apply(long) - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
- apply(long) - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
- apply(long, double) - Method in class org.apache.druid.math.expr.vector.DoubleOutLongDoubleInFunctionVectorValueProcessor
- apply(long, double) - Method in class org.apache.druid.math.expr.vector.LongOutLongDoubleInFunctionVectorValueProcessor
- apply(long, long) - Method in class org.apache.druid.math.expr.vector.DoubleOutLongsInFunctionVectorValueProcessor
- apply(long, long) - Method in class org.apache.druid.math.expr.vector.LongOutLongsInFunctionVectorValueProcessor
- apply(long, long) - Method in interface org.apache.druid.query.aggregation.firstlast.SelectionPredicate
- apply(OutputStream) - Method in interface org.apache.druid.java.util.common.FileUtils.OutputStreamConsumer
- apply(Object) - Method in class org.apache.druid.query.extraction.BucketExtractionFn
- apply(Object) - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
- apply(Object) - Method in class org.apache.druid.query.extraction.DimExtractionFn
- apply(Object) - Method in interface org.apache.druid.query.extraction.ExtractionFn
-
The "extraction" function.
- apply(Object) - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
- apply(Object) - Method in class org.apache.druid.query.extraction.JavaScriptExtractionFn
- apply(Object) - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
- apply(Object) - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
- apply(String) - Method in class org.apache.druid.data.input.ColumnsFilter
-
Check if a column should be included or not.
- apply(String) - Method in class org.apache.druid.data.input.ColumnsFilter.ExclusionBased
- apply(String) - Method in class org.apache.druid.data.input.ColumnsFilter.InclusionBased
- apply(String) - Method in class org.apache.druid.query.extraction.BucketExtractionFn
- apply(String) - Method in class org.apache.druid.query.extraction.CascadeExtractionFn
- apply(String) - Method in interface org.apache.druid.query.extraction.ExtractionFn
-
The "extraction" function.
- apply(String) - Method in class org.apache.druid.query.extraction.FunctionalExtraction
- apply(String) - Method in class org.apache.druid.query.extraction.IdentityExtractionFn
- apply(String) - 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(String) - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
- apply(String) - Method in class org.apache.druid.query.extraction.UpperExtractionFn
- apply(String) - Method in class org.apache.druid.query.lookup.ImmutableLookupMap.ImmutableLookupExtractor
- apply(String) - Method in class org.apache.druid.query.lookup.LookupExtractor
-
Apply a particular lookup methodology to the input string
- apply(String) - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
- apply(String, int, Object) - Method in interface org.apache.druid.query.CacheStrategy.AddToResultFunction
- apply(List<Expr>) - Method in class org.apache.druid.math.expr.BuiltInExprMacros.ComplexDecodeBase64ExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.math.expr.BuiltInExprMacros.StringDecodeBase64UTFExprMacro
- apply(List<Expr>) - Method in interface org.apache.druid.math.expr.ExprMacroTable.ExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.ArrayQuantileExprMacro
- 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.HyperUniqueExpressions.HllAddExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.HyperUniqueExpressions.HllCreateExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.HyperUniqueExpressions.HllEstimateExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.HyperUniqueExpressions.HllRoundEstimateExprMacro
- 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.IPv6AddressMatchExprMacro
- 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.NestedDataExpressions.JsonKeysExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonObjectExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonPathsExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonQueryArrayExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonQueryExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonValueExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.NestedDataExpressions.ParseJsonExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.NestedDataExpressions.ToJsonStringExprMacro
- apply(List<Expr>) - Method in class org.apache.druid.query.expression.NestedDataExpressions.TryParseJsonExprMacro
- 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.RegexpReplaceExprMacro
- 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(List<Expr>, Expr.ObjectBinding) - Method in interface org.apache.druid.math.expr.Function
-
Evaluate the function, given a list of arguments and a set of bindings to provide values for
IdentifierExpr
. - apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ArrayConstructorFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ArrayLengthFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ArrayScalarFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ArraysFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ArraySliceFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.BivariateFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.CaseSearchedFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.CaseSimpleFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.CoalesceFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ConcatFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ConditionFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.IsDistinctFromFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.IsFalseFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.IsNotDistinctFromFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.IsNotFalseFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.IsNotNullFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.IsNotTrueFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.IsNullFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.IsTrueFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.LowerFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.LpadFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ParseLong
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.Pi
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ReduceFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.ReplaceFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.Round
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.RpadFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.SizeFormatFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.StringFormatFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.StringToArrayFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.StrlenFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.StrposFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.SubMonthFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.SubstringFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.TimestampFromEpochFunc
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.UnivariateFunction
- apply(List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.Function.UpperFunc
- apply(InputRow) - Method in class org.apache.druid.segment.incremental.SpatialDimensionRowTransformer
- apply(Event) - Method in class org.apache.druid.java.util.emitter.core.FeedUriExtractor
- apply(Event) - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriExtractor
- apply(Event) - Method in interface org.apache.druid.java.util.emitter.core.UriExtractor
- apply(LambdaExpr, List<Expr>, Expr.ObjectBinding) - Method in interface org.apache.druid.math.expr.ApplyFunction
- apply(LambdaExpr, List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldFunction
- apply(LambdaExpr, List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianMapFunction
- apply(LambdaExpr, List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.FilterFunction
- apply(LambdaExpr, List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.FoldFunction
- apply(LambdaExpr, List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.MapFunction
- apply(LambdaExpr, List<Expr>, Expr.ObjectBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.MatchFunction
- apply(ResultRow, ResultRow) - Method in class org.apache.druid.query.groupby.epinephelinae.GroupByResultMergeFn
- 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(T) - Method in interface org.apache.druid.query.filter.DruidObjectPredicate
- apply(T) - Method in class org.apache.druid.query.filter.FallbackPredicate
- apply(Type1, Type2, Type3) - Method in interface org.apache.druid.java.util.common.guava.nary.TrinaryFn
- applyAll(Iterable<String>) - Method in class org.apache.druid.query.lookup.LookupExtractor
- applyAsInt(IntKey) - Method in interface org.apache.druid.query.groupby.epinephelinae.IntGrouper.IntGrouperHashFunction
- applyCorrection(double, int) - Static method in class org.apache.druid.hll.HyperLogLogCollector
- applyDouble(double) - Method in interface org.apache.druid.query.filter.DruidDoublePredicate
- applyFloat(float) - Method in interface org.apache.druid.query.filter.DruidFloatPredicate
- ApplyFunction - Interface in org.apache.druid.math.expr
-
Base interface describing the mechanism used to evaluate an
ApplyFunctionExpr
, which 'applies' aLambdaExpr
to one or more arrayExpr
. - ApplyFunction.AllMatchFunction - Class in org.apache.druid.math.expr
-
Evaluates to true if all element of the array input
Expr
causes theLambdaExpr
to evaluate to a 'truthy' value - ApplyFunction.AnyMatchFunction - Class in org.apache.druid.math.expr
-
Evaluates to true if any element of the array input
Expr
causes theLambdaExpr
to evaluate to a 'truthy' value - ApplyFunction.BaseFoldFunction - Class in org.apache.druid.math.expr
-
Base class for family of
ApplyFunction
which aggregate a scalar or array value given one or more array inputExpr
arguments and an array or scalar "accumulator" argument with an initial value - ApplyFunction.BaseMapFunction - Class in org.apache.druid.math.expr
-
Base class for "map" functions, which are a class of
ApplyFunction
which take a lambda function that is mapped to the values of anApplyFunction.IndexableMapLambdaObjectBinding
which is created from the outerExpr.ObjectBinding
and the values of the arrayExpr
argument(s) - ApplyFunction.CartesianFoldFunction - Class in org.apache.druid.math.expr
-
Accumulate a value for the cartesian product of 'n' array inputs arguments with an 'n + 1' argument
LambdaExpr
. - ApplyFunction.CartesianFoldLambdaBinding - Class in org.apache.druid.math.expr
- ApplyFunction.CartesianMapFunction - Class in org.apache.druid.math.expr
-
Map the cartesian product of 'n' array input arguments to an 'n' argument
LambdaExpr
- ApplyFunction.CartesianMapLambdaBinding - Class in org.apache.druid.math.expr
- ApplyFunction.FilterFunction - Class in org.apache.druid.math.expr
-
Filter an array to all elements that evaluate to a 'truthy' value for a
LambdaExpr
- ApplyFunction.FoldFunction - Class in org.apache.druid.math.expr
-
Accumulate a value for a single array input with a 2 argument
LambdaExpr
. - ApplyFunction.FoldLambdaBinding - Class in org.apache.druid.math.expr
- ApplyFunction.IndexableFoldLambdaBinding - Interface in org.apache.druid.math.expr
-
Expr.ObjectBinding
which can be iterated by an integer index position forApplyFunction.BaseFoldFunction
. - ApplyFunction.IndexableMapLambdaObjectBinding - Interface in org.apache.druid.math.expr
-
Expr.ObjectBinding
which can be iterated by an integer index position forApplyFunction.BaseMapFunction
. - ApplyFunction.LambdaInputBindingInspector - Class in org.apache.druid.math.expr
-
Helper that can wrap another
Expr.InputBindingInspector
to use to supply the type information of aLambdaExpr
when evaluatingExpr.getOutputType(org.apache.druid.math.expr.Expr.InputBindingInspector)
. - ApplyFunction.MapFunction - Class in org.apache.druid.math.expr
-
Map the scalar values of a single array input
Expr
to a single argumentLambdaExpr
- ApplyFunction.MapLambdaBinding - Class in org.apache.druid.math.expr
- ApplyFunction.MatchFunction - Class in org.apache.druid.math.expr
-
Base class for family of
ApplyFunction
which evaluate elements elements of a single array input against aLambdaExpr
to evaluate to a final 'truthy' value - ApplyFunction.SettableLambdaBinding - Class in org.apache.druid.math.expr
-
Simple, mutable,
Expr.ObjectBinding
for aLambdaExpr
which provides aMap
for storing arbitrary values to use as values forIdentifierExpr
in the body of the lambda that are arguments to the lambda - ApplyFunctionExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.ApplyFunctionExprContext
- 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.FluentQueryRunner
- applyPostProcessing(Sequence<ResultRow>, GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupingEngine
-
Apply the
GroupByQuery
"postProcessingFn", which is responsible for HavingSpec and LimitSpec. - applyPreMergeDecoration() - Method in class org.apache.druid.query.FluentQueryRunner
- applyUnappliedBindings(Expr, Expr.BindingAnalysis, List<String>) - Static method in class org.apache.druid.math.expr.Parser
- 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
- archive(DataSegment) - Method in interface org.apache.druid.segment.loading.DataSegmentArchiver
-
Perform an archive task on the segment and return the resulting segment or null if there was no action needed.
- 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
- areKeysUnique(boolean) - Method in interface org.apache.druid.segment.join.table.IndexedTable.Index
-
Returns whether keys are unique in this index.
- areKeysUnique(boolean) - Method in class org.apache.druid.segment.join.table.MapIndex
- areKeysUnique(boolean) - Method in class org.apache.druid.segment.join.table.UniqueLongArrayIndex
- ArenaMemoryAllocator - Class in org.apache.druid.frame.allocation
-
Allocator that uses a reusable
WritableMemory
arena. - ArenaMemoryAllocatorFactory - Class in org.apache.druid.frame.allocation
-
Creates
ArenaMemoryAllocator
on each call toArenaMemoryAllocatorFactory.newAllocator()
. - ArenaMemoryAllocatorFactory(int) - Constructor for class org.apache.druid.frame.allocation.ArenaMemoryAllocatorFactory
- areNumeric(List<Expr>) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Check if all provided
Expr
can infer the output type asTypeSignature.isNumeric()
with a value of true (or null, which is not a type) There must be at least one expression with a computable numeric output type for this method to return true. - areNumeric(Expr...) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Check if all provided
Expr
can infer the output type asTypeSignature.isNumeric()
with a value of true (or null, which is not a type) There must be at least one expression with a computable numeric output type for this method to return true. - areReadableChannelsReady() - Method in class org.apache.druid.frame.processor.OutputChannels
- areSameTypes(List<Expr>) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Check if all arguments are the same type (or null, which is not a type) This method should only be used if
Expr.InputBindingInspector.getType(java.lang.String)
produces accurate information for all bindings (no null value for type unless the input binding does not exist and so the input is always null) - areSameTypes(Expr...) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Check if all arguments are the same type (or null, which is not a type) This method should only be used if
Expr.InputBindingInspector.getType(java.lang.String)
produces accurate information for all bindings (no null value for type unless the input binding does not exist and so the input is always null) - areScalar(List<Expr>) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Check if all provided
Expr
can infer the output type asTypeSignature.isPrimitive()
(non-array) with a value of true (or null, which is not a type) There must be at least one expression with a computable scalar output type for this method to return true. - areScalar(Expr...) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Check if all provided
Expr
can infer the output type asTypeSignature.isPrimitive()
(non-array) with a value of true (or null, which is not a type) There must be at least one expression with a computable scalar output type for this method to return true. - areSomeColumnsFromJoin(Collection<String>) - Method in class org.apache.druid.segment.join.filter.JoinableClauses
- ARG_JOINER - Static variable in interface org.apache.druid.math.expr.Expr
- args - Variable in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- 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() - Method in class org.apache.druid.frame.key.RowKey
-
Get the backing array for this key (not a copy).
- ARRAY - org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
- ARRAY - org.apache.druid.java.util.emitter.core.BatchingStrategy
- ARRAY - org.apache.druid.math.expr.ExprType
- ARRAY - org.apache.druid.segment.column.ValueType
-
Placeholder for arbitrary arrays of other
ValueType
. - ARRAY_COMPARATOR - Static variable in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- ARRAY_DICTIONARY_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- ARRAY_ELEMENT_BITMAP_INDEX_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- ARRAY_ELEMENT_DICTIONARY_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- ARRAY_ELEMENT_NOT_NULL_BYTE - Static variable in class org.apache.druid.frame.field.NumericFieldWriter
-
Indicator byte denoting that the numeric value succeeding it is not null.
- ARRAY_ELEMENT_NULL_BYTE - Static variable in class org.apache.druid.frame.field.NumericFieldWriter
-
Indicator byte denoting that the numeric value succeeding it is null.
- ARRAY_OF_DOUBLES_SKETCH_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- ARRAY_OF_DOUBLES_SKETCH_CONSTANT_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_BASE64_STRING_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_METRICS_SUM_ESTIMATE_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
- ARRAY_TERMINATOR - Static variable in class org.apache.druid.frame.field.NumericArrayFieldWriter
-
Marks the end of the array.
- ARRAY_TYPE - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- ARRAY_TYPE - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- ARRAY_TYPE() - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitArrayContext
- ArrayAddElementFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayAddElementFunction
- ArrayAppendFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayAppendFunction
- 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
- ArrayComparator(Comparator<T>) - Constructor for class org.apache.druid.query.DimensionComparisonUtils.ArrayComparator
- ArrayComparatorForUnnaturalStringComparator(StringComparator) - Constructor for class org.apache.druid.query.DimensionComparisonUtils.ArrayComparatorForUnnaturalStringComparator
- ArrayConcatFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayConcatFunction
- ArrayConstructorFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayConstructorFunction
- ArrayContainsElementFilter - Class in org.apache.druid.query.filter
-
Check to see if an array contains a specific element.
- ArrayContainsElementFilter(String, ColumnType, Object, FilterTuning) - Constructor for class org.apache.druid.query.filter.ArrayContainsElementFilter
- ArrayContainsFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayContainsFunction
- ArrayDictionaryMergingIterator(Iterable<Object[]>[], DictionaryIdLookup) - Constructor for class org.apache.druid.segment.AutoTypeColumnMerger.ArrayDictionaryMergingIterator
- ArrayElementIndexes - Interface in org.apache.druid.segment.index.semantic
-
Construct a
BitmapColumnIndex
for any array element which might be present in an array contained in the column. - arrayElements - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- ArrayLengthFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayLengthFunction
- ArrayListRowsAndColumns<RowType> - Class in org.apache.druid.query.rowsandcols
-
ArrayListRowsAndColumns is a RowsAndColumns implementation that believes it has all of its data on-heap.
- ArrayListRowsAndColumns(ArrayList<RowType>, RowAdapter<RowType>, RowSignature) - Constructor for class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- ArrayListSegment<RowType> - Class in org.apache.druid.segment
-
A
Segment
that is based on a stream of objects. - ArrayListSegment(SegmentId, ArrayList<RowType>, RowAdapter<RowType>, RowSignature) - Constructor for class org.apache.druid.segment.ArrayListSegment
-
Create a list-based segment.
- ArrayOffsetFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayOffsetFunction
- ArrayOffsetOfFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayOffsetOfFunction
- ArrayOrdinalFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayOrdinalFunction
- ArrayOrdinalOfFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayOrdinalOfFunction
- ArrayOverlapFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- ArrayPrependFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayPrependFunction
- ArrayQuantileExprMacro - Class in org.apache.druid.query.expression
-
Computes a particular quantile from a numeric array.
- ArrayQuantileExprMacro() - Constructor for class org.apache.druid.query.expression.ArrayQuantileExprMacro
- ArrayScalarFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayScalarFunction
- ArraySetAddAllFunction() - Constructor for class org.apache.druid.math.expr.Function.ArraySetAddAllFunction
- ArraySetAddFunction() - Constructor for class org.apache.druid.math.expr.Function.ArraySetAddFunction
- ArraysFunction() - Constructor for class org.apache.druid.math.expr.Function.ArraysFunction
- ArraySliceFunction() - Constructor for class org.apache.druid.math.expr.Function.ArraySliceFunction
- ArraysMergeFunction() - Constructor for class org.apache.druid.math.expr.Function.ArraysMergeFunction
- ArrayToMultiValueStringFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- ArrayToStringFunction() - Constructor for class org.apache.druid.math.expr.Function.ArrayToStringFunction
- ArrayTypeStrategy(TypeSignature<?>) - Constructor for class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
- ArrayVectorValueMatcher - Class in org.apache.druid.query.filter.vector
- ArrayVectorValueMatcher(TypeSignature<ValueType>, VectorObjectSelector) - Constructor for class org.apache.druid.query.filter.vector.ArrayVectorValueMatcher
- as(Class<? extends T>) - Method in interface org.apache.druid.query.rowsandcols.column.Column
-
Asks the Column to return itself as a concrete implementation of a specific interface.
- as(Class<? extends T>) - Method in class org.apache.druid.query.rowsandcols.column.ColumnAccessorBasedColumn
- as(Class<? extends T>) - Method in class org.apache.druid.query.rowsandcols.column.ConstantObjectColumn
- as(Class<? extends T>) - Method in class org.apache.druid.query.rowsandcols.column.DoubleArrayColumn
- as(Class<? extends T>) - Method in class org.apache.druid.query.rowsandcols.column.IntArrayColumn
- as(Class<? extends T>) - Method in class org.apache.druid.query.rowsandcols.column.LimitedColumn
- as(Class<? extends T>) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn
- as(Class<? extends T>) - Method in class org.apache.druid.query.rowsandcols.column.ObjectArrayColumn
- as(Class<? extends T>) - Method in class org.apache.druid.query.rowsandcols.concrete.ColumnHolderRACColumn
- as(Class<T>) - Method in class org.apache.druid.frame.segment.FrameSegment
- as(Class<T>) - Method in class org.apache.druid.math.expr.ExpressionPredicateIndexSupplier
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.AppendableMapOfColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.ConcatRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.concrete.ColumnBasedFrameRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.concrete.QueryableIndexRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.concrete.RowBasedFrameRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.EmptyRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.LazilyDecoratedRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.LimitedRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.RearrangedRowsAndColumns
- as(Class<T>) - Method in interface org.apache.druid.query.rowsandcols.RowsAndColumns
-
Asks the RowsAndColumns to return itself as a concrete implementation of a specific interface.
- as(Class<T>) - Method in class org.apache.druid.query.rowsandcols.StorageAdapterRowsAndColumns
- as(Class<T>) - Method in class org.apache.druid.segment.ArrayListSegment
- as(Class<T>) - Method in interface org.apache.druid.segment.CloseableShapeshifter
-
Asks the Object to return itself as a concrete implementation of a specific interface.
- as(Class<T>) - Method in interface org.apache.druid.segment.column.ColumnIndexSupplier
-
Try to get a column 'index' of the specified type.
- as(Class<T>) - Method in class org.apache.druid.segment.join.HashJoinSegment
- as(Class<T>) - Method in class org.apache.druid.segment.nested.NestedDataColumnSupplier
- as(Class<T>) - Method in class org.apache.druid.segment.nested.NestedFieldColumnIndexSupplier
- as(Class<T>) - Method in class org.apache.druid.segment.nested.ScalarDoubleColumnAndIndexSupplier
- as(Class<T>) - Method in class org.apache.druid.segment.nested.ScalarLongColumnAndIndexSupplier
- as(Class<T>) - Method in class org.apache.druid.segment.nested.ScalarStringColumnAndIndexSupplier
- as(Class<T>) - Method in class org.apache.druid.segment.nested.VariantColumnAndIndexSupplier
- as(Class<T>) - Method in class org.apache.druid.segment.QueryableIndexSegment
- as(Class<T>) - Method in class org.apache.druid.segment.ReferenceCountingSegment
- as(Class<T>) - Method in interface org.apache.druid.segment.Segment
-
Request an implementation of a particular interface.
- as(Class<T>) - Method in class org.apache.druid.segment.serde.NoIndexesColumnIndexSupplier
- as(Class<T>) - Method in class org.apache.druid.segment.serde.NullValueIndexSupplier
- as(Class<T>) - Method in class org.apache.druid.segment.serde.StringUtf8ColumnIndexSupplier
- asArray() - Method in class org.apache.druid.math.expr.ExprEval
- asArrayType() - Method in class org.apache.druid.math.expr.ExprEval
- asArrayType(ExpressionType) - Static method in class org.apache.druid.math.expr.ExpressionType
-
Convert a primitive
ExpressionType
into an array of that type. - asBoolean() - Method in class org.apache.druid.math.expr.ExprEval
- asBoolean(double) - Static method in class org.apache.druid.math.expr.Evals
- asBoolean(long) - Static method in class org.apache.druid.math.expr.Evals
- asBoolean(String) - Static method in class org.apache.druid.math.expr.Evals
- asBuffer(ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- asBuilder() - Method in class org.apache.druid.java.util.emitter.core.EventMap
-
Convert this EventMap to a builder.
- asByte() - Method in enum org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.VERSION
- asc(String) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- ASC - org.apache.druid.query.operator.ColumnWithDirection.Direction
- ascending(String) - Static method in class org.apache.druid.query.operator.ColumnWithDirection
- ascending(String...) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- ASCENDING - org.apache.druid.frame.key.KeyOrder
-
Ordered ascending.
- ASCENDING - org.apache.druid.query.groupby.orderby.OrderByColumnSpec.Direction
- ASCENDING - org.apache.druid.query.scan.ScanQuery.Order
- asColumnIndexSupplier(ColumnIndexSelector, ColumnType) - Method in interface org.apache.druid.math.expr.Expr
- asDouble() - Method in class org.apache.druid.math.expr.ExprEval
-
Get the primitive double value.
- asDouble(boolean) - Static method in class org.apache.druid.math.expr.Evals
- asEval() - Method in class org.apache.druid.math.expr.vector.BivariateFunctionVectorProcessor
- asEval() - Method in class org.apache.druid.math.expr.vector.LongOutObjectInFunctionVectorProcessor
- asEval() - Method in class org.apache.druid.math.expr.vector.UnivariateFunctionVectorObjectProcessor
- asin(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Asin() - Constructor for class org.apache.druid.math.expr.Function.Asin
- 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. - asInt() - Method in class org.apache.druid.math.expr.ExprEval
-
Get the primitive integer value.
- asLong() - Method in class org.apache.druid.math.expr.ExprEval
-
Get the primitive long value.
- asLong(boolean) - Static method in class org.apache.druid.math.expr.Evals
- asLookupExtractor(boolean, Supplier<byte[]>) - Method in class org.apache.druid.query.lookup.ImmutableLookupMap
- asMap() - Method in class org.apache.druid.data.input.ListBasedInputRow
- asMap() - Method in class org.apache.druid.math.expr.SettableObjectBinding
- asMap() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
- asMap() - Method in class org.apache.druid.query.lookup.ImmutableLookupMap.ImmutableLookupExtractor
- asMap() - Method in class org.apache.druid.query.lookup.LookupExtractor
-
Returns a Map view of this lookup extractor.
- asMap() - Method in class org.apache.druid.query.QueryContext
- asMap(ObjectMapper) - Method in class org.apache.druid.segment.IndexSpec
- asMemory(ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- asQueryableIndex() - Method in class org.apache.druid.frame.segment.FrameSegment
- asQueryableIndex() - Method in class org.apache.druid.segment.ArrayListSegment
- 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
- asQueryableIndex() - Method in class org.apache.druid.segment.WrappedSegmentReference
- asSingleThreaded(List<Expr>, Expr.InputBindingInspector) - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- asSingleThreaded(List<Expr>, Expr.InputBindingInspector) - Method in class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- asSingleThreaded(List<Expr>, Expr.InputBindingInspector) - Method in interface org.apache.druid.math.expr.Function
- asSingleThreaded(List<Expr>, Expr.InputBindingInspector) - Method in class org.apache.druid.math.expr.Function.ScalarInArrayFunction
- asSingleThreaded(Expr.InputBindingInspector) - Method in interface org.apache.druid.math.expr.Expr
- asStorageAdapter() - Method in class org.apache.druid.frame.segment.FrameSegment
- asStorageAdapter() - Method in class org.apache.druid.segment.ArrayListSegment
- 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
- asStorageAdapter() - Method in class org.apache.druid.segment.WrappedSegmentReference
- asString() - Method in class org.apache.druid.math.expr.ExprEval
- asString() - Method in class org.apache.druid.segment.ReferenceCountingSegment
- asString() - Method in interface org.apache.druid.segment.Segment
- asString(Object) - Static method in class org.apache.druid.math.expr.Evals
-
Call
Object.toString()
on a non-null value - ASSUME_GROUPED - Static variable in interface org.apache.druid.indexer.partitions.DimensionBasedPartitionsSpec
- asTypeString() - Method in interface org.apache.druid.segment.column.TypeSignature
-
Convert a
TypeSignature
into a simple string. - asValueMatcher() - Method in enum org.apache.druid.segment.filter.ConstantMatcherType
- asVectorMatcher(VectorSizeInspector) - Method in enum org.apache.druid.segment.filter.ConstantMatcherType
- asVectorProcessor(Expr.VectorInputBindingInspector) - Method in interface org.apache.druid.math.expr.Expr
-
Builds a 'vectorized' expression processor, that can operate on batches of input values for use in vectorized query engines.
- asVectorProcessor(Expr.VectorInputBindingInspector) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Abs
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Acos
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Asin
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in interface org.apache.druid.math.expr.Function
-
Builds a 'vectorized' function expression processor, that can build vectorized processors for its input values using
Expr.asVectorProcessor(org.apache.druid.math.expr.Expr.VectorInputBindingInspector)
, for use in vectorized query engines. - asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Atan
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Atan2
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseAnd
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseComplement
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseConvertDoubleToLongBits
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseConvertLongBitsToDouble
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseOr
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseShiftLeft
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseShiftRight
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseXor
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CastFunc
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Cbrt
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Ceil
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CoalesceFunc
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ConcatFunc
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CopySign
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Cos
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Cosh
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Cot
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Div
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Exp
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Expm1
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Floor
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.GetExponent
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Hypot
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotNullFunc
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNullFunc
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Log
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Log10
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Log1p
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Max
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Min
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.NextAfter
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.NextUp
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ParseLong
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Pi
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Pow
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Remainder
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Rint
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Scalb
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Signum
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Sin
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Sinh
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Sqrt
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Tan
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Tanh
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ToDegrees
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ToRadians
- asVectorProcessor(Expr.VectorInputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Ulp
- asVectorProcessor(Expr.VectorInputBindingInspector, Expr, List<Expr>) - Method in interface org.apache.druid.math.expr.ApplyFunction
-
Builds a 'vectorized' function expression processor, that can build vectorized processors for its input values using
Expr.asVectorProcessor(org.apache.druid.math.expr.Expr.VectorInputBindingInspector)
, for use in vectorized query engines. - asVisual() - Method in class org.apache.druid.query.aggregation.Histogram
-
Returns a visual representation of a histogram object.
- asWritableBuffer(ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- asWritableMemory(ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- ASYNC - org.apache.druid.query.ExecutionMode
-
This mode executes the query in a non-blocking way.
- atan(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Atan() - Constructor for class org.apache.druid.math.expr.Function.Atan
- atan2(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Atan2() - Constructor for class org.apache.druid.math.expr.Function.Atan2
- AuditEntry - Class in org.apache.druid.audit
-
Serializable record of an audit event that can be persisted, logged or sent over REST APIs.
- AuditEntry(String, String, AuditInfo, RequestInfo, AuditEntry.Payload, DateTime) - Constructor for class org.apache.druid.audit.AuditEntry
- AuditEntry.Builder - Class in org.apache.druid.audit
- AuditEntry.Payload - Class in org.apache.druid.audit
-
Payload of an
AuditEntry
that may be specifiedAuditEntry.Payload.raw()
orAuditEntry.Payload.serialized()
. - auditInfo(AuditInfo) - Method in class org.apache.druid.audit.AuditEntry.Builder
- AuditInfo - Class in org.apache.druid.audit
-
Contains information about the author who performed an audited operation.
- AuditInfo(String, String, String, String) - Constructor for class org.apache.druid.audit.AuditInfo
- AuditManager - Interface in org.apache.druid.audit
- auditTime(DateTime) - Method in class org.apache.druid.audit.AuditEntry.Builder
- AUTO - org.apache.druid.segment.data.CompressionFactory.LongEncodingStrategy
-
AUTO strategy scans all values once before encoding them.
- autoDetect(ExprEval, ExprEval) - Static method in class org.apache.druid.math.expr.ExpressionTypeConversion
-
Given 2 'input' types, which might not be fully trustable, choose the most appropriate combined type for non-vectorized, per-row type detection.
- AUTOMATIC - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
- AutoTypeColumnIndexer - Class in org.apache.druid.segment
- AutoTypeColumnIndexer(String, ColumnType) - Constructor for class org.apache.druid.segment.AutoTypeColumnIndexer
- AutoTypeColumnMerger - Class in org.apache.druid.segment
-
Column merger for
AutoTypeColumnIndexer
to eventually produce some form ofNestedCommonFormatColumn
. - AutoTypeColumnMerger(String, ColumnType, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.AutoTypeColumnMerger
- AutoTypeColumnMerger.ArrayDictionaryMergingIterator - Class in org.apache.druid.segment
- AutoTypeColumnMerger.IdLookupArrayIterator - Class in org.apache.druid.segment
- AutoTypeColumnSchema - Class in org.apache.druid.segment
-
Common
DimensionSchema
for ingestion of 'standard' Druid built-inColumnType
datatypes. - AutoTypeColumnSchema(String, ColumnType) - Constructor for class org.apache.druid.segment.AutoTypeColumnSchema
- available() - Method in class org.apache.druid.data.input.impl.RetryingInputStream
- available() - Method in class org.apache.druid.frame.allocation.ArenaMemoryAllocator
- available() - Method in class org.apache.druid.frame.allocation.HeapMemoryAllocator
- available() - Method in interface org.apache.druid.frame.allocation.MemoryAllocator
-
Returns the number of bytes available for allocations.
- available() - Method in class org.apache.druid.io.ByteBufferInputStream
- available() - Method in class org.apache.druid.java.util.http.client.io.AppendableByteArrayInputStream
- awaitAll(int) - Static method in class org.apache.druid.frame.processor.ReturnOrAwait
-
Wait for all of a certain number of channels.
- awaitAll(IntSet) - Static method in class org.apache.druid.frame.processor.ReturnOrAwait
-
Wait for all provided channels to become readable (or finished).
- awaitAny(IntSet) - Method in class org.apache.druid.frame.processor.AwaitAnyWidget
-
Returns a future that resolves when any channel in the provided set is ready for reading.
- awaitAny(IntSet) - Static method in class org.apache.druid.frame.processor.ReturnOrAwait
-
Wait for any of the provided channels to become readable (or finished).
- AwaitAnyWidget - Class in org.apache.druid.frame.processor
- AwaitAnyWidget(List<ReadableFrameChannel>) - Constructor for class org.apache.druid.frame.processor.AwaitAnyWidget
- awaitCount(long) - Method in class org.apache.druid.concurrent.ConcurrentAwaitableCounter
-
Await until the
ConcurrentAwaitableCounter.increment()
is called on this counter object the specified number of times from the creation of this counter object. - awaitCount(long, long, TimeUnit) - Method in class org.apache.druid.concurrent.ConcurrentAwaitableCounter
-
Await until the
ConcurrentAwaitableCounter.increment()
is called on this counter object the specified number of times from the creation of this counter object, for not longer than the specified period of time. - awaitFirstIncrement(long, TimeUnit) - Method in class org.apache.druid.concurrent.ConcurrentAwaitableCounter
-
The difference between this method and
ConcurrentAwaitableCounter.awaitCount(long, long, TimeUnit)
with argument 1 is thatawaitFirstIncrement()
returns boolean designating whether the count was await (while waiting for no longer than for the specified period of time), whileawaitCount()
throwsTimeoutException
if the count was not awaited. - awaitInitialization() - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
-
awaitToInitialise blocks and wait for the cache to initialize fully.
- awaitNextIncrements(long) - Method in class org.apache.druid.concurrent.ConcurrentAwaitableCounter
-
Somewhat loosely defined wait for "next N increments", because the starting point is not defined from the Java Memory Model perspective.
- awaitNextRetry(Throwable, String, int, int, boolean) - Static method in class org.apache.druid.java.util.common.RetryUtils
- awaitSet() - Method in class org.apache.druid.frame.processor.ReturnOrAwait
-
The set of channels the processors wants to wait for.
- awaitStarted() - Method in class org.apache.druid.concurrent.LifecycleLock
-
Awaits until
LifecycleLock.exitStart()
is called, if needed, and returnstrue
ifLifecycleLock.started()
was called before that. - awaitStarted(long, TimeUnit) - Method in class org.apache.druid.concurrent.LifecycleLock
-
Awaits until
LifecycleLock.exitStart()
is called for at most the specified timeout, and returnstrue
ifLifecycleLock.started()
was called before that. - awaitTermination(long, TimeUnit) - Method in class org.apache.druid.java.util.common.concurrent.DirectExecutorService
- awaitTermination(long, TimeUnit) - Method in class org.apache.druid.query.PrioritizedExecutorService
B
- backpressureFuture() - Method in class org.apache.druid.frame.file.FrameFilePartialFetch
-
Future that resolves when it is a good time to request the next chunk of the frame file.
- BAD_QUERY_CONTEXT_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- BadJsonQueryException - Exception in org.apache.druid.query
- BadJsonQueryException(JsonParseException) - Constructor for exception org.apache.druid.query.BadJsonQueryException
- BadQueryContextException - Exception in org.apache.druid.query
- BadQueryContextException(String) - Constructor for exception org.apache.druid.query.BadQueryContextException
- BadQueryException - Exception in org.apache.druid.query
-
An abstract class for all query exceptions that should return a bad request status code (400).
- BadQueryException(String, String, String) - Constructor for exception org.apache.druid.query.BadQueryException
- BadQueryException(String, String, String, String) - Constructor for exception org.apache.druid.query.BadQueryException
- BadQueryException(Throwable, String, String, String, String) - Constructor for exception org.apache.druid.query.BadQueryException
- badTypeException(String, String, Object) - Static method in class org.apache.druid.query.QueryContexts
- badValueException(String, String, Object) - Static method in class org.apache.druid.query.QueryContexts
- BASE_SLEEP_MILLIS - Static variable in class org.apache.druid.java.util.common.RetryUtils
- 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
- BaseDimensionRangeShardSpec - Class in org.apache.druid.timeline.partition
- BaseDimensionRangeShardSpec(List<String>, StringTuple, StringTuple) - Constructor for class org.apache.druid.timeline.partition.BaseDimensionRangeShardSpec
- 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
- BaseExpressionColumnValueSelector - Class in org.apache.druid.segment.virtual
-
Base class for many (although not all)
ColumnValueSelector<ExprEval>
. - BaseExpressionColumnValueSelector(RowIdSupplier) - Constructor for class org.apache.druid.segment.virtual.BaseExpressionColumnValueSelector
- BaseFailure - Class in org.apache.druid.error
-
DruidException.Failure
for a specific errorCode, category and persona. - BaseFailure(String, DruidException.Persona, DruidException.Category, Throwable, String, Object...) - Constructor for class org.apache.druid.error.BaseFailure
- 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
- BaseFoldFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.BaseFoldFunction
- BaseHttpEmittingConfig - Class in org.apache.druid.java.util.emitter.core
- BaseHttpEmittingConfig() - Constructor for class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- BaseImmutableRTee - Interface in org.apache.druid.collections.spatial
- BaseInjectorBuilder<T extends BaseInjectorBuilder<?>> - Class in org.apache.druid.guice
-
Utilities for building a Guice injector.
- BaseInjectorBuilder() - Constructor for class org.apache.druid.guice.BaseInjectorBuilder
- baseInspector - Variable in class org.apache.druid.segment.virtual.VirtualizedColumnInspector
- 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
- BaseMacroFunctionExpr(ExprMacroTable.ExprMacro, List<Expr>) - Constructor for class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
-
Constructor for subclasses.
- BaseMapFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.BaseMapFunction
- 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
- BaseScalarMacroFunctionExpr(ExprMacroTable.ExprMacro, List<Expr>) - Constructor for class org.apache.druid.math.expr.ExprMacroTable.BaseScalarMacroFunctionExpr
- baseSelector - Variable in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
- baseSelector - Variable in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- BaseSequence<T,IterType extends Iterator<T>> - Class in org.apache.druid.java.util.common.guava
- BaseSequence(BaseSequence.IteratorMaker<T, IterType>) - Constructor for class org.apache.druid.java.util.common.guava.BaseSequence
- BaseSequence.IteratorMaker<T,IterType extends Iterator<T>> - Interface in org.apache.druid.java.util.common.guava
- 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
- BaseTypeSignature<Type extends TypeDescriptor> - Class in org.apache.druid.segment.column
- BaseTypeSignature(TypeFactory, Type, String, TypeSignature<Type>) - Constructor for class org.apache.druid.segment.column.BaseTypeSignature
- BaseValueSetIndexesFromIterable(BitmapFactory, Indexed<ImmutableBitmap>, Supplier<ImmutableBitmap>) - Constructor for class org.apache.druid.segment.index.semantic.ValueSetIndexes.BaseValueSetIndexesFromIterable
- BaseVectorValueMatcher - Class in org.apache.druid.query.filter.vector
- BaseVectorValueMatcher(VectorSizeInspector) - Constructor for class org.apache.druid.query.filter.vector.BaseVectorValueMatcher
- BasicCredentials - Class in org.apache.druid.java.util.http.client.auth
- BasicCredentials(String, String) - Constructor for class org.apache.druid.java.util.http.client.auth.BasicCredentials
- BasicMonitorScheduler - Class in org.apache.druid.java.util.metrics
-
A
MonitorScheduler
implementation based onScheduledExecutorService
. - BasicMonitorScheduler(DruidMonitorSchedulerConfig, ServiceEmitter, List<Monitor>, ScheduledExecutorService) - Constructor for class org.apache.druid.java.util.metrics.BasicMonitorScheduler
- batchEndLength() - Method in enum org.apache.druid.java.util.emitter.core.BatchingStrategy
- BatchingStrategy - Enum in org.apache.druid.java.util.emitter.core
- 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(PeekableIntIterator) - Constructor for class org.apache.druid.collections.bitmap.BatchIteratorAdapter
- batchSize(int) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- batchStartLength() - Method in enum org.apache.druid.java.util.emitter.core.BatchingStrategy
- before() - Method in class org.apache.druid.java.util.common.guava.SequenceWrapper
-
Executed before sequence processing, i.
- bestEffortArray(List<?>) - Static method in class org.apache.druid.math.expr.ExprEval
- BestEffortInputBindings() - Constructor for class org.apache.druid.math.expr.InputBindings.BestEffortInputBindings
- bestEffortOf(Object) - Static method in class org.apache.druid.math.expr.ExprEval
-
Examine java type to find most appropriate expression type
- BINARY_BYTE - org.apache.druid.java.util.common.HumanReadableBytes.UnitSystem
-
also known as IEC format eg: B, KiB, MiB, GiB ...
- BinarySearchableAccessor - Interface in org.apache.druid.query.rowsandcols.column
- binaryVersion(Integer) - Method in class org.apache.druid.timeline.DataSegment.Builder
- bind(Binder, Class<T>) - Static method in class org.apache.druid.guice.ConfigProvider
-
Deprecated.
- bind(Binder, String, Class<T>) - Static method in class org.apache.druid.guice.JsonConfigProvider
- bind(Binder, String, Class<T>, Key<T>, Key<Supplier<T>>) - Static method in class org.apache.druid.guice.JsonConfigProvider
- bind(Binder, String, Class<T>, Annotation) - Static method in class org.apache.druid.guice.JsonConfigProvider
- bind(Binder, String, Class<T>, Class<? extends Annotation>) - Static method in class org.apache.druid.guice.JsonConfigProvider
- bind(Binder, String, Class<T>, Class<? extends T>, Key<T>, Key<Supplier<T>>) - Static method in class org.apache.druid.guice.JsonConfigProvider
- bind(Binder, String, Class<T>, T) - Static method in class org.apache.druid.guice.JacksonConfigProvider
- Binders - Class in org.apache.druid.guice
- Binders() - Constructor for class org.apache.druid.guice.Binders
- BindingAnalysis() - Constructor for class org.apache.druid.math.expr.Expr.BindingAnalysis
- bindInstance(Binder, Key<T>, T) - Static method in class org.apache.druid.guice.JsonConfigProvider
- bindWithDefault(Binder, String, Class<T>, Class<? extends T>) - Static method in class org.apache.druid.guice.JsonConfigProvider
- bins - Variable in class org.apache.druid.query.aggregation.Histogram
- BitIterator - Class in org.apache.druid.extendedset.intset
- bitmap - Variable in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
- BITMAP_INDEX_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- BitmapColumnIndex - Interface in org.apache.druid.segment.index
-
Common interface for bitmap indexes for use by
Filter
for cursor creation, to allow fast row skipping during query processing. - BitmapFactory - Interface in org.apache.druid.collections.bitmap
- 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
- 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
- bitmapWriter - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- BITS_FOR_BUCKETS - Static variable in class org.apache.druid.hll.HyperLogLogCollector
- 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
- bitwiseAnd(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- BitwiseAnd() - Constructor for class org.apache.druid.math.expr.Function.BitwiseAnd
- bitwiseComplement(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- BitwiseComplement() - Constructor for class org.apache.druid.math.expr.Function.BitwiseComplement
- bitwiseConvertDoubleToLongBits(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- BitwiseConvertDoubleToLongBits() - Constructor for class org.apache.druid.math.expr.Function.BitwiseConvertDoubleToLongBits
- bitwiseConvertLongBitsToDouble(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- BitwiseConvertLongBitsToDouble() - Constructor for class org.apache.druid.math.expr.Function.BitwiseConvertLongBitsToDouble
- bitwiseOr(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- BitwiseOr() - Constructor for class org.apache.druid.math.expr.Function.BitwiseOr
- bitwiseShiftLeft(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- BitwiseShiftLeft() - Constructor for class org.apache.druid.math.expr.Function.BitwiseShiftLeft
- bitwiseShiftRight(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- BitwiseShiftRight() - Constructor for class org.apache.druid.math.expr.Function.BitwiseShiftRight
- bitwiseXor(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- BitwiseXor() - Constructor for class org.apache.druid.math.expr.Function.BitwiseXor
- BivariateBitwiseMathFunction() - Constructor for class org.apache.druid.math.expr.Function.BivariateBitwiseMathFunction
- BivariateDoubleFunctionVectorValueProcessor<TLeftInput,TRightInput> - Class in org.apache.druid.math.expr.vector
-
common machinery for processing two input operators and functions, which should always treat null inputs as null output, and are backed by a primitive values instead of an object values (and need to use the null vectors instead of checking the vector themselves for nulls) this one is specialized for producing double[], see
BivariateLongFunctionVectorValueProcessor
for long[] primitives. - BivariateDoubleFunctionVectorValueProcessor(ExprVectorProcessor<TLeftInput>, ExprVectorProcessor<TRightInput>, int) - Constructor for class org.apache.druid.math.expr.vector.BivariateDoubleFunctionVectorValueProcessor
- BivariateFunction() - Constructor for class org.apache.druid.math.expr.Function.BivariateFunction
- BivariateFunctionVectorObjectProcessor<TLeftInput,TRightInput,TOutput> - Class in org.apache.druid.math.expr.vector
-
Base
ExprVectorProcessor
for expressions and functions with 2 'object' typed inputs (strings, arrays). - BivariateFunctionVectorObjectProcessor(ExprVectorProcessor<TLeftInput>, ExprVectorProcessor<TRightInput>, TOutput) - Constructor for class org.apache.druid.math.expr.vector.BivariateFunctionVectorObjectProcessor
- BivariateFunctionVectorProcessor<TLeftInput,TRightInput,TOutput> - Class in org.apache.druid.math.expr.vector
-
Basic vector processor that processes 2 inputs and works for both primitive value vectors and object vectors.
- BivariateFunctionVectorProcessor(ExpressionType, ExprVectorProcessor<TLeftInput>, ExprVectorProcessor<TRightInput>) - Constructor for class org.apache.druid.math.expr.vector.BivariateFunctionVectorProcessor
- BivariateLongFunctionVectorValueProcessor<TLeftInput,TRightInput> - Class in org.apache.druid.math.expr.vector
-
common machinery for processing two input operators and functions, which should always treat null inputs as null output, and are backed by a primitive values instead of an object values (and need to use the null vectors instead of checking the vector themselves for nulls) this one is specialized for producing long[], see
BivariateDoubleFunctionVectorValueProcessor
for double[] primitives. - BivariateLongFunctionVectorValueProcessor(ExprVectorProcessor<TLeftInput>, ExprVectorProcessor<TRightInput>, int) - Constructor for class org.apache.druid.math.expr.vector.BivariateLongFunctionVectorValueProcessor
- BivariateMathFunction() - Constructor for class org.apache.druid.math.expr.Function.BivariateMathFunction
- BlockCompressedPayloadBuffer - Class in org.apache.druid.segment.serde.cell
- BlockCompressedPayloadBuffer(ByteBuffer, ByteBuffer, BlockIndexWriter, WriteOutBytes, Closer, CompressionStrategy.Compressor) - Constructor for class org.apache.druid.segment.serde.cell.BlockCompressedPayloadBuffer
- BlockCompressedPayloadBufferFactory - Class in org.apache.druid.segment.serde.cell
- BlockCompressedPayloadBufferFactory(ByteBufferProvider, SegmentWriteOutMedium, CompressionStrategy.Compressor) - Constructor for class org.apache.druid.segment.serde.cell.BlockCompressedPayloadBufferFactory
- BlockCompressedPayloadReader - Class in org.apache.druid.segment.serde.cell
- BlockCompressedPayloadSerializer - Class in org.apache.druid.segment.serde.cell
- BlockCompressedPayloadSerializer(BlockIndexWriter, WriteOutBytes) - Constructor for class org.apache.druid.segment.serde.cell.BlockCompressedPayloadSerializer
- BlockCompressedPayloadWriter - Class in org.apache.druid.segment.serde.cell
- BlockCompressedPayloadWriter.Builder - Class in org.apache.druid.segment.serde.cell
- BlockIndexWriter - Class in org.apache.druid.segment.serde.cell
- BlockIndexWriter(WriteOutBytes) - Constructor for class org.apache.druid.segment.serde.cell.BlockIndexWriter
- BlockingPool<T> - Interface in org.apache.druid.collections
- BlockingQueueFrameChannel - Class in org.apache.druid.frame.channel
-
In-memory channel backed by a limited-capacity
Deque
. - BlockingQueueFrameChannel(int) - Constructor for class org.apache.druid.frame.channel.BlockingQueueFrameChannel
-
Create a channel with a particular buffer size (expressed in number of frames).
- BlockingQueueOutputChannelFactory - Class in org.apache.druid.frame.processor
-
An
OutputChannelFactory
that generatesBlockingQueueFrameChannel
. - BlockingQueueOutputChannelFactory(int) - Constructor for class org.apache.druid.frame.processor.BlockingQueueOutputChannelFactory
- BlockLayoutColumnarDoublesSerializer - Class in org.apache.druid.segment.data
-
Serializer that produces
BlockLayoutColumnarDoublesSupplier.BlockLayoutColumnarDoubles
. - 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
-
Serializer that produces
BlockLayoutColumnarFloatsSupplier.BlockLayoutColumnarFloats
. - 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
-
Serializer that produces
BlockLayoutColumnarLongsSupplier.BlockLayoutColumnarLongs
. - 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
- BooleanVectorValueMatcher - Class in org.apache.druid.query.filter.vector
- BothTrimExprMacro() - Constructor for class org.apache.druid.query.expression.TrimExprMacro.BothTrimExprMacro
- Bouncer - Class in org.apache.druid.frame.processor
-
Limiter for access to some resource.
- Bouncer(int) - Constructor for class org.apache.druid.frame.processor.Bouncer
- Bouncer.Ticket - Class in org.apache.druid.frame.processor
- bound(String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
- Bound<TCoordinateArray,TPoint extends ImmutableNode<TCoordinateArray>> - Interface in org.apache.druid.collections.spatial.search
- BoundDimFilter - Class in org.apache.druid.query.filter
-
Recommended to use
RangeFilter
instead - BoundDimFilter(String, String, String, Boolean, Boolean, Boolean, ExtractionFn, StringComparator) - Constructor for class org.apache.druid.query.filter.BoundDimFilter
- BoundDimFilter(String, String, String, Boolean, Boolean, Boolean, ExtractionFn, StringComparator, FilterTuning) - 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(Iterable<ImmutableNode>, Bound, int) - Method in class org.apache.druid.collections.spatial.search.GutmanSearchStrategy
- breadthFirstSearch(ImmutableNode, Bound) - 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
- BROKER_SERVICE_NAME - Static variable in class org.apache.druid.query.QueryContexts
- bucket(DateTime) - Method in class org.apache.druid.java.util.common.granularity.Granularity
-
Return a granularity-sized Interval containing a particular DateTime.
- BUCKET - org.apache.druid.data.input.impl.systemfield.SystemField
- BUCKET_HASH - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- BUCKET_RANGE - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- BUCKET_SINGLE_DIM - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- bucketComparator(RowSignature) - Method in class org.apache.druid.frame.key.ClusterBy
-
Comparator that compares bucket keys for this instance.
- 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".
- bucketEnd(DateTime) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- 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. - BucketNumberedShardSpec<T extends BuildingShardSpec> - Interface in org.apache.druid.timeline.partition
-
This is one of the special shardSpecs which are temporarily used during batch ingestion.
- bucketSize - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- bucketSize - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- bucketSize() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
-
Returns the size in bytes of each bucket.
- bucketSize(int, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
-
Returns the size of each bucket in a table.
- bucketSizeWithHash - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- bucketsPosition - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- bucketStart(long) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- bucketStart(long) - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- bucketStart(long) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- bucketStart(long) - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- bucketStart(long) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- bucketStart(DateTime) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- bucketStart(DateTime) - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- bucketStart(DateTime) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- bucketStart(DateTime) - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- bucketStart(DateTime) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- 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 - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- 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() - 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
- bufferComparator(int, StringComparator) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FixedWidthGroupByColumnSelectorStrategy
- 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.KeyMappingMultiValueGroupByColumnSelectorStrategy.DictionaryBuilding
- bufferComparator(int, StringComparator) - Method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.PrebuiltDictionary
- 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, int) - 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
- BufferIndexed() - Constructor for class org.apache.druid.segment.data.GenericIndexed.BufferIndexed
- bufferSupplier - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- build() - Method in class org.apache.druid.audit.AuditEntry.Builder
- build() - Method in class org.apache.druid.data.input.impl.DimensionsSpec.Builder
- build() - Method in class org.apache.druid.frame.write.InvalidFieldException.Builder
- build() - Method in class org.apache.druid.frame.write.InvalidNullByteException.Builder
- build() - Method in class org.apache.druid.guice.BaseInjectorBuilder
- build() - Method in class org.apache.druid.java.util.emitter.core.EventMap.Builder
-
Builds and returns the EventMap
- build() - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- build() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- build() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexColumn.Builder
- build() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn.Builder
- build() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn.Builder
- build() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn.Builder
- 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() - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.Builder
- build() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- build() - Method in class org.apache.druid.query.operator.join.JoinPartDefn.Builder
- build() - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns.Builder
- 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.IdMapping.Builder
- build() - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- build() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
- build() - Method in class org.apache.druid.segment.IndexSpec.Builder
- build() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
- build() - Method in class org.apache.druid.segment.join.table.RowBasedIndexBuilder
-
Create the index.
- build() - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter.Builder
- build() - Method in class org.apache.druid.segment.serde.cell.CellReader.Builder
- build() - Method in class org.apache.druid.segment.serde.cell.CellWriter.Builder
- 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() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.SerializerBuilder
- build() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- build() - Method in class org.apache.druid.timeline.DataSegment.Builder
- build(ImmutableMap<String, String>) - Method in class org.apache.druid.java.util.emitter.service.AlertBuilder
- build(ImmutableMap<String, String>) - Method in class org.apache.druid.java.util.emitter.service.ServiceEventBuilder
- build(ImmutableMap<String, String>) - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent.Builder
- build(String, Object...) - Method in class org.apache.druid.error.DruidException.DruidExceptionBuilder
- build(String, String) - Method in class org.apache.druid.java.util.emitter.service.ServiceEventBuilder
- build(Throwable, String, Object...) - Method in class org.apache.druid.error.DruidException.DruidExceptionBuilder
- build(Granularity) - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder
- build(DataSource, JoinConditionAnalysis) - Method in class org.apache.druid.segment.join.FrameBasedInlineJoinableFactory
- build(DataSource, JoinConditionAnalysis) - Method in class org.apache.druid.segment.join.InlineJoinableFactory
- 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(DataSource, JoinConditionAnalysis) - Method in class org.apache.druid.segment.join.NoopJoinableFactory
- build(GroupByQuery) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
- 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_SEGMENTS - org.apache.druid.indexer.IngestionState
- 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(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
- 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(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
- 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(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
- buildAllowListIdMapping(Set<String>, int, IdLookup, ListFilteredDimensionSpec.IndexedGetter<String>) - Static method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
- buildBitmapColumnIndexFromIteratorBinarySearch(BitmapFactory, Iterable<T>, Indexed<T>, Indexed<ImmutableBitmap>, Supplier<ImmutableBitmap>) - Static method in interface org.apache.druid.segment.index.semantic.ValueSetIndexes
-
Helper method for implementing
ValueSetIndexes.forSortedValues(java.util.List<?>, org.apache.druid.segment.column.TypeSignature<org.apache.druid.segment.column.ValueType>)
for a value set that is NOT sorted the same as the column dictionary. - buildBitmapColumnIndexFromSortedIteratorBinarySearch(BitmapFactory, Iterable<T>, Indexed<T>, Indexed<ImmutableBitmap>, Supplier<ImmutableBitmap>) - Static method in interface org.apache.druid.segment.index.semantic.ValueSetIndexes
-
Helper method for implementing
ValueSetIndexes.forSortedValues(java.util.List<?>, org.apache.druid.segment.column.TypeSignature<org.apache.druid.segment.column.ValueType>)
for a value set that is sorted the same as the column dictionary. - buildBitmapColumnIndexFromSortedIteratorScan(BitmapFactory, Comparator<T>, Iterable<T>, Indexed<T>, Indexed<ImmutableBitmap>, Supplier<ImmutableBitmap>) - Static method in interface org.apache.druid.segment.index.semantic.ValueSetIndexes
-
Helper method for implementing
ValueSetIndexes.forSortedValues(java.util.List<?>, org.apache.druid.segment.column.TypeSignature<org.apache.druid.segment.column.ValueType>)
for a value set that is sorted the same as the column dictionary. - 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(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
- 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(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
- 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(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
- buildDenyListIdMapping(Set<String>, int, ListFilteredDimensionSpec.IndexedGetter<String>) - Static method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
- builder - Variable in class org.apache.druid.query.DefaultQueryMetrics
- builder() - Static method in class org.apache.druid.audit.AuditEntry
- builder() - Static method in class org.apache.druid.data.input.impl.DimensionsSpec
- builder() - Static method in exception org.apache.druid.frame.write.InvalidFieldException
- builder() - Static method in exception org.apache.druid.frame.write.InvalidNullByteException
- builder() - Static method in class org.apache.druid.java.util.emitter.core.EventMap
-
Returns builder with Fluent API to build EventMap instance using method chaining
- builder() - Static method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- builder() - Static method in class org.apache.druid.java.util.http.client.HttpClientConfig
- builder() - Method in class org.apache.druid.java.util.metrics.FeedDefiningMonitor
- builder() - Method in class org.apache.druid.java.util.metrics.HttpPostEmitterMonitor
- builder() - Static method in class org.apache.druid.query.groupby.GroupByQuery
- builder() - Static method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
- builder() - Static method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- builder() - Static method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- builder() - Static method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
- builder() - Static method in class org.apache.druid.segment.column.ColumnDescriptor
- builder() - Static method in class org.apache.druid.segment.column.RowSignature
- builder() - Method in interface org.apache.druid.segment.incremental.AppendableIndexSpec
- builder() - Static method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
- builder() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex.Spec
- builder() - Static method in class org.apache.druid.segment.IndexSpec
- builder() - Static method in class org.apache.druid.timeline.DataSegment
- builder(ByteBuffer) - Static method in class org.apache.druid.segment.serde.cell.CellReader
- builder(InvalidFieldException) - Static method in exception org.apache.druid.frame.write.InvalidFieldException
- builder(InvalidNullByteException) - Static method in exception org.apache.druid.frame.write.InvalidNullByteException
- builder(Operator) - Static method in class org.apache.druid.query.operator.join.JoinPartDefn
- builder(SegmentWriteOutMedium) - Static method in class org.apache.druid.segment.serde.cell.CellWriter
- builder(DataSegment) - Static method in class org.apache.druid.timeline.DataSegment
- Builder() - Constructor for class org.apache.druid.data.input.impl.DimensionsSpec.Builder
- Builder() - Constructor for class org.apache.druid.frame.write.InvalidFieldException.Builder
- Builder() - Constructor for class org.apache.druid.frame.write.InvalidNullByteException.Builder
- Builder() - Constructor for class org.apache.druid.java.util.emitter.core.EventMap.Builder
- Builder() - Constructor for class org.apache.druid.java.util.emitter.service.ServiceMetricEvent.Builder
- Builder() - Constructor for class org.apache.druid.query.groupby.GroupByQuery.Builder
- Builder() - Constructor for class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- Builder() - Constructor for class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns.Builder
- Builder() - Constructor for class org.apache.druid.query.topn.DimValHolder.Builder
- Builder() - Constructor for class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
- Builder() - Constructor for class org.apache.druid.segment.column.ColumnDescriptor.Builder
- Builder() - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
- Builder() - Constructor for class org.apache.druid.segment.incremental.OnheapIncrementalIndex.Builder
- Builder() - Constructor for class org.apache.druid.segment.IndexSpec.Builder
- Builder() - Constructor for class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- Builder() - Constructor for class org.apache.druid.timeline.DataSegment.Builder
- Builder(String) - Constructor for class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- Builder(ByteBuffer) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexColumn.Builder
- Builder(ByteBuffer) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn.Builder
- Builder(ByteBuffer) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn.Builder
- Builder(ByteBuffer) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn.Builder
- Builder(ByteBuffer) - Constructor for class org.apache.druid.segment.serde.cell.CellReader.Builder
-
The default block size is 64k as provided by NativeClearedByteBufferProvider.
- Builder(InvalidFieldException) - Constructor for class org.apache.druid.frame.write.InvalidFieldException.Builder
- Builder(InvalidNullByteException) - Constructor for class org.apache.druid.frame.write.InvalidNullByteException.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(Operator) - Constructor for class org.apache.druid.query.operator.join.JoinPartDefn.Builder
- Builder(JoinFilterPreAnalysisKey, List<VirtualColumn>) - Constructor for class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
- Builder(SegmentWriteOutMedium) - Constructor for class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter.Builder
- Builder(SegmentWriteOutMedium) - Constructor for class org.apache.druid.segment.serde.cell.CellWriter.Builder
-
Default instance with a
NativeClearedByteBufferProvider
- Builder(DataSegment) - Constructor for class org.apache.druid.timeline.DataSegment.Builder
- buildFilter(Filter, Interval) - Static method in class org.apache.druid.frame.segment.FrameCursorUtils
- buildGroupIteratorFor(AppendableRowsAndColumns, WindowFrame) - Static method in class org.apache.druid.query.rowsandcols.semantic.DefaultFramedOnHeapAggregatable
- buildHttpEmitterConfig(String) - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitterConfig
- BUILDING_HASHED - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- BUILDING_NUMBERED - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- BUILDING_RANGE - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- BUILDING_SINGLE_DIM - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- BuildingDimensionRangeShardSpec - Class in org.apache.druid.timeline.partition
-
See
BuildingShardSpec
for how this class is used. - BuildingDimensionRangeShardSpec(int, List<String>, StringTuple, StringTuple, int) - Constructor for class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- BuildingHashBasedNumberedShardSpec - Class in org.apache.druid.timeline.partition
-
See
BuildingShardSpec
for how this class is used. - BuildingHashBasedNumberedShardSpec(int, int, int, List<String>, HashPartitionFunction, ObjectMapper) - Constructor for class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- BuildingNumberedShardSpec - Class in org.apache.druid.timeline.partition
-
See
BuildingShardSpec
for how this class is used. - BuildingNumberedShardSpec(int) - Constructor for class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- BuildingShardSpec<T extends ShardSpec> - Interface in org.apache.druid.timeline.partition
-
This is one of the special shardSpecs which are temporarily used during batch ingestion.
- BuildingSingleDimensionShardSpec - Class in org.apache.druid.timeline.partition
-
See
BuildingShardSpec
for how this class is used. - BuildingSingleDimensionShardSpec(int, String, String, String, int) - Constructor for class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- buildInner() - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- buildInner() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex.Builder
- buildInputParams(String) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnector
- buildInputParams(String, long, long) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnector
- 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
- buildSafeSignature(ImmutableList<String>) - Method in class org.apache.druid.segment.column.RowSignature
-
Builds a safe
RowSignature
. - buildStringKeyMap(ByteBuffer) - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- buildTaskReports(TaskReport...) - Static method in interface org.apache.druid.indexer.report.TaskReport
-
Returns an order-preserving map that is suitable for passing into
TaskReportFileWriter.write(java.lang.String, org.apache.druid.indexer.report.TaskReport.ReportMap)
. - buildVectorized(int) - Method in class org.apache.druid.segment.QueryableIndexCursorSequenceBuilder
- BuiltInExprMacros - Class in org.apache.druid.math.expr
- BuiltInExprMacros() - Constructor for class org.apache.druid.math.expr.BuiltInExprMacros
- BuiltInExprMacros.ComplexDecodeBase64ExprMacro - Class in org.apache.druid.math.expr
- BuiltInExprMacros.StringDecodeBase64UTFExprMacro - Class in org.apache.druid.math.expr
- builtInFactories() - Static method in interface org.apache.druid.segment.writeout.SegmentWriteOutMediumFactory
- BundleInfo(FilterBundle.IndexBundleInfo, FilterBundle.MatcherBundleInfo) - Constructor for class org.apache.druid.query.filter.FilterBundle.BundleInfo
- BY_SEGMENT_KEY - Static variable in class org.apache.druid.query.QueryContexts
- 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
- ByteBitLookup - Class in org.apache.druid.hll
- ByteBitLookup() - Constructor for class org.apache.druid.hll.ByteBitLookup
- 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
- ByteBufferInputRowParser - Interface in org.apache.druid.data.input
- ByteBufferInputStream - Class in org.apache.druid.io
-
Streams bytes from the
ByteBuffer
's position to the limit asInputStream
. - ByteBufferInputStream(ByteBuffer) - Constructor for class org.apache.druid.io.ByteBufferInputStream
-
Does *not* make a copy of the given buffer, so the position of the given buffer is incremented, as the created InputStream is used.
- 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
- ByteBufferProvider - Interface in org.apache.druid.segment.serde.cell
- ByteBufferUtils - Class in org.apache.druid.java.util.common
- ByteBufferUtils() - Constructor for class org.apache.druid.java.util.common.ByteBufferUtils
- 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
- ByteEntity - Class in org.apache.druid.data.input.impl
- ByteEntity(byte[]) - Constructor for class org.apache.druid.data.input.impl.ByteEntity
- ByteEntity(ByteBuffer) - Constructor for class org.apache.druid.data.input.impl.ByteEntity
-
Create a new entity.
- byteKeyComparator(RowSignature) - Method in class org.apache.druid.frame.key.ClusterBy
-
Comparator that compares byte arrays of keys for this instance using the given signature directly.
- ByteRowKeyComparator - Class in org.apache.druid.frame.key
-
Comparator for byte arrays from
RowKey.key
instances. - Bytes(InputStream) - Constructor for class org.apache.druid.data.input.impl.FastLineIterator.Bytes
- Bytes(InputRowSchema, InputEntity) - Constructor for class org.apache.druid.data.input.TextReader.Bytes
- BytesCountingInputEntity - Class in org.apache.druid.data.input
-
Wrapper around an
InputEntity
that counts the number of bytes read. - BytesCountingInputEntity(InputEntity, InputStats) - Constructor for class org.apache.druid.data.input.BytesCountingInputEntity
- BytesFullResponseHandler - Class in org.apache.druid.java.util.http.client.response
-
HttpResponseHandler
for stream data of byte array type. - BytesFullResponseHandler() - Constructor for class org.apache.druid.java.util.http.client.response.BytesFullResponseHandler
- BytesFullResponseHolder - Class in org.apache.druid.java.util.http.client.response
- BytesFullResponseHolder(HttpResponse) - Constructor for class org.apache.druid.java.util.http.client.response.BytesFullResponseHolder
- byteSize() - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
- bytesLeft() - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- bytesToTransfer() - Method in interface org.apache.druid.query.rowsandcols.semantic.WireTransferable
- ByteTracker - Class in org.apache.druid.frame.channel
-
Tracks the byte usage with an upper bound bytes limit.
- ByteTracker(long) - Constructor for class org.apache.druid.frame.channel.ByteTracker
- ByteUtils - Class in org.apache.druid.common.utils
- BZ2 - org.apache.druid.utils.CompressionUtils.Format
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_LIST_FALLBACK - Static variable in class org.apache.druid.segment.virtual.VirtualColumnCacheHelper
- CACHE_TYPE_ID_LIST_FILTERED - Static variable in class org.apache.druid.segment.virtual.VirtualColumnCacheHelper
- 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
- Cacheable - Interface in org.apache.druid.java.util.common
- 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
- 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.
- calculateHaversineDistance(double, double, double, double) - Static method in class org.apache.druid.collections.spatial.RTreeUtils
-
Returns distance between two geo coordinates in meters according to https://en.wikipedia.org/wiki/Haversine_formula
- 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
- call() - Method in class org.apache.druid.common.guava.ThreadRenamingCallable
- 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.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 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
- cancel(String) - Method in class org.apache.druid.frame.processor.FrameProcessorExecutor
-
Cancels all processors associated with a given cancellationId.
- cancelAll(boolean, Future<?>, List<F>) - Static method in class org.apache.druid.common.guava.GuavaUtils
-
Cancel futures manually, because sometime we can't cancel all futures in {code com.google.common.util.concurrent.Futures.CombinedFuture} automatically.
- CANCELED - org.apache.druid.error.DruidException.Category
-
Means that the query was canceled for some reason
- CANCELED - org.apache.druid.query.QueryException.FailType
- canCompare() - Method in class org.apache.druid.segment.data.DecompressingByteBufferObjectStrategy
- canCompare() - Method in interface org.apache.druid.segment.data.ObjectStrategy
-
Whether
Comparator.compare(T, T)
is valid or not. - canCompareAsString(DateTime) - Static method in class org.apache.druid.java.util.common.DateTimes
-
Returns true if the provided DateTime can be compared against other DateTimes using its string representation.
- canCompareEndpointsAsStrings(Interval) - Static method in class org.apache.druid.java.util.common.Intervals
-
Returns true if the provided interval has endpoints that can be compared against other DateTimes using their string representations.
- canCompareIds() - Method in interface org.apache.druid.query.groupby.epinephelinae.column.DimensionIdCodec
-
Returns if the object comparison can be optimised directly by comparing the dictionaryIds, instead of decoding the objects and comparing those.
- canDrop() - Method in class org.apache.druid.query.context.ResponseContext.AbstractKey
- canDrop() - Method in interface org.apache.druid.query.context.ResponseContext.Key
-
Returns true if this key can be removed to reduce header size when the header would otherwise be too large.
- 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.
- canMapOverDictionary(Expr.BindingAnalysis, ColumnCapabilities) - 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.
- cannotVectorize() - Static method in class org.apache.druid.math.expr.Exprs
- cannotVectorize(String) - Static method in class org.apache.druid.math.expr.Exprs
- cannotVectorize(Expr) - Static method in class org.apache.druid.math.expr.Exprs
- cannotVectorize(Function) - Static method in class org.apache.druid.math.expr.Exprs
- 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.GroupByQueryEngine
-
check if a column will operate correctly with
LimitedBufferHashGrouper
for query limit pushdown - canRead() - Method in class org.apache.druid.frame.channel.ComposingReadableFrameChannel
- canRead() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
- canRead() - Method in class org.apache.druid.frame.channel.ReadableConcatFrameChannel
- canRead() - Method in class org.apache.druid.frame.channel.ReadableFileFrameChannel
- canRead() - Method in interface org.apache.druid.frame.channel.ReadableFrameChannel
-
Returns whether this channel has a frame or error condition currently available.
- canRead() - Method in class org.apache.druid.frame.channel.ReadableInputStreamFrameChannel
- canRead() - Method in class org.apache.druid.frame.channel.ReadableNilFrameChannel
- 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
- canStart() - Method in class org.apache.druid.concurrent.LifecycleLock
-
Start latch, only one canStart() call in any thread on this LifecycleLock object could return true, if
LifecycleLock.exitStopAndReset()
is not called in between. - canStop() - Method in class org.apache.druid.concurrent.LifecycleLock
-
Stop latch, only one canStop() call in any thread on this LifecycleLock object could return
true
. - canVectorize() - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
- canVectorize() - Method in interface org.apache.druid.query.dimension.DimensionSpec
-
Does this DimensionSpec have working
DimensionSpec.decorate(SingleValueDimensionVectorSelector)
andDimensionSpec.decorate(MultiValueDimensionVectorSelector)
methods? - canVectorize(List<Expr>) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Check if every provided
Expr
computesExpr.canVectorize(InputBindingInspector)
to a value of true - canVectorize(Expr.InputBindingInspector) - Method in interface org.apache.druid.math.expr.Expr
-
Check if an expression can be 'vectorized', for a given set of inputs.
- canVectorize(Expr.InputBindingInspector) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BivariateBitwiseMathFunction
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BivariateMathFunction
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in interface org.apache.druid.math.expr.Function
-
Check if a function can be 'vectorized', for a given set of
Expr
inputs. - canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CastFunc
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CoalesceFunc
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ConcatFunc
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotNullFunc
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNullFunc
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ParseLong
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Pi
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.SafeDivide
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Scalb
- canVectorize(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.UnivariateMathFunction
- canVectorize(Expr.InputBindingInspector, Expr, List<Expr>) - Method in interface org.apache.druid.math.expr.ApplyFunction
-
Check if an apply function can be 'vectorized', for a given
LambdaExpr
and set ofExpr
inputs. - canVectorize(Expr...) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Check if every provided
Expr
computesExpr.canVectorize(InputBindingInspector)
to a value of true - canVectorize(Filter, VirtualColumns, boolean) - Method in class org.apache.druid.frame.segment.columnar.FrameCursorFactory
- canVectorize(Filter, VirtualColumns, boolean) - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- 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.join.HashJoinSegmentStorageAdapter
- canVectorize(Filter, VirtualColumns, boolean) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
- canVectorize(GroupByQuery, StorageAdapter, Filter) - Static method in class org.apache.druid.query.groupby.epinephelinae.vector.VectorGroupByEngine
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Returns whether or not this aggregation class supports vectorization.
- 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.cardinality.CardinalityAggregatorFactory
- 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.firstlast.first.DoubleFirstAggregatorFactory
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- canVectorize(ColumnInspector) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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(ColumnInspector) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- canVectorize(ColumnInspector) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- canVectorize(ColumnInspector) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- canVectorize(ColumnInspector) - Method in interface org.apache.druid.segment.VirtualColumn
- canVectorize(ColumnInspector) - Method in class org.apache.druid.segment.VirtualColumns
- canVectorize(ColumnInspector, String, String, Supplier<Expr>) - Static method in class org.apache.druid.query.aggregation.AggregatorUtil
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.query.filter.EqualityFilter
- canVectorizeMatcher(ColumnInspector) - Method in interface org.apache.druid.query.filter.Filter
-
Returns true if this filter can produce a vectorized matcher from its "makeVectorMatcher" method.
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.query.filter.InDimFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.query.filter.NullFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.query.filter.RangeFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.query.filter.TypedInFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.AndFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.BoundFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.ExpressionFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.FalseFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.IsBooleanFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.LikeFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.NotFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.OrFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.SelectorFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.SpatialFilter
- canVectorizeMatcher(ColumnInspector) - Method in class org.apache.druid.segment.filter.TrueFilter
- capabilities - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- capabilities(String) - Method in class org.apache.druid.frame.util.SettableLongVirtualColumn
- capabilities(String) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- capabilities(String) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- capabilities(String) - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- capabilities(String) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- capabilities(String) - Method in interface org.apache.druid.segment.VirtualColumn
-
Deprecated.
- capabilities(ColumnInspector, String) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- capabilities(ColumnInspector, String) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- capabilities(ColumnInspector, String) - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- capabilities(ColumnInspector, String) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- 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. - CAPABILITIES - Static variable in class org.apache.druid.segment.index.SimpleBitmapColumnIndex
- CapabilitiesBasedFormat - Class in org.apache.druid.segment.column
- CapabilitiesBasedFormat(ColumnCapabilities) - Constructor for class org.apache.druid.segment.column.CapabilitiesBasedFormat
- capacity() - Method in class org.apache.druid.frame.allocation.ArenaMemoryAllocator
- capacity() - Method in class org.apache.druid.frame.allocation.HeapMemoryAllocator
- capacity() - Method in interface org.apache.druid.frame.allocation.MemoryAllocator
-
Returns the number of bytes managed by this allocator.
- CAPACITY_EXCEEDED - org.apache.druid.error.DruidException.Category
-
Means that some capacity limit was exceeded, this could be due to throttling or due to some system limit
- CAPACITY_EXCEEDED - org.apache.druid.query.QueryException.FailType
- CARD_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- cardinality - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- CARDINALITY - org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
- 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
- CardinalityVectorAggregator - Class in org.apache.druid.query.aggregation.cardinality
- CardinalityVectorProcessor - Interface in org.apache.druid.query.aggregation.cardinality.vector
-
Processor for
CardinalityVectorAggregator
. - CardinalityVectorProcessorFactory - Class in org.apache.druid.query.aggregation.cardinality.vector
- CardinalityVectorProcessorFactory() - Constructor for class org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- CartesianFoldFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.CartesianFoldFunction
- CartesianList<E> - Class in org.apache.druid.math.expr
-
CartesianList
computes the cartesian product of n lists. - CartesianMapFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.CartesianMapFunction
- 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
- CaseSearchedFunc() - Constructor for class org.apache.druid.math.expr.Function.CaseSearchedFunc
- CaseSimpleFunc() - Constructor for class org.apache.druid.math.expr.Function.CaseSimpleFunc
- cast(ExprVectorProcessor<?>, ExpressionType) - Static method in class org.apache.druid.math.expr.vector.CastToTypeVectorProcessor
- castForEqualityComparison(ExprEval<?>, ExpressionType) - Static method in class org.apache.druid.math.expr.ExprEval
-
Cast an
ExprEval
to someExpressionType
that the value will be compared with. - CastFunc() - Constructor for class org.apache.druid.math.expr.Function.CastFunc
- castObjectSelectorToNumeric(ReadableVectorInspector, String, VectorObjectSelector, ColumnType, ColumnType) - Static method in class org.apache.druid.segment.virtual.ExpressionVectorSelectors
- castTo(ExpressionType) - Method in class org.apache.druid.math.expr.ExprEval
- CastToDoubleVectorProcessor - Class in org.apache.druid.math.expr.vector
- CastToDoubleVectorProcessor(ExprVectorProcessor<?>) - Constructor for class org.apache.druid.math.expr.vector.CastToDoubleVectorProcessor
- castToExpressionType - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
- CastToLongVectorProcessor - Class in org.apache.druid.math.expr.vector
- CastToLongVectorProcessor(ExprVectorProcessor<?>) - Constructor for class org.apache.druid.math.expr.vector.CastToLongVectorProcessor
- CastToStringVectorProcessor - Class in org.apache.druid.math.expr.vector
- CastToStringVectorProcessor(ExprVectorProcessor<?>) - Constructor for class org.apache.druid.math.expr.vector.CastToStringVectorProcessor
- castToType - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
- CastToTypeVectorProcessor<TOutput> - Class in org.apache.druid.math.expr.vector
- CastToTypeVectorProcessor(ExprVectorProcessor<?>) - Constructor for class org.apache.druid.math.expr.vector.CastToTypeVectorProcessor
- castValueSelectorToObject(ReadableVectorInspector, String, VectorValueSelector, ColumnType, ColumnType) - Static method in class org.apache.druid.segment.virtual.ExpressionVectorSelectors
- CATEGORY - Static variable in class org.apache.druid.query.DruidMetrics
- cbrt(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Cbrt() - Constructor for class org.apache.druid.math.expr.Function.Cbrt
- ceil(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Ceil() - Constructor for class org.apache.druid.math.expr.Function.Ceil
- CellIndexReader - Class in org.apache.druid.segment.serde.cell
- CellIndexReader(BlockCompressedPayloadReader) - Constructor for class org.apache.druid.segment.serde.cell.CellIndexReader
- CellIndexWriter - Class in org.apache.druid.segment.serde.cell
- CellIndexWriter(BlockCompressedPayloadWriter) - Constructor for class org.apache.druid.segment.serde.cell.CellIndexWriter
- CellReader - Class in org.apache.druid.segment.serde.cell
-
CellReader is intended to read the data written byte
CellWriter
. - CellReader.Builder - Class in org.apache.druid.segment.serde.cell
- CellWriter - Class in org.apache.druid.segment.serde.cell
-
usage:
- CellWriter.Builder - Class in org.apache.druid.segment.serde.cell
- CENTURY - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- CgroupCpuMonitor - Class in org.apache.druid.java.util.metrics
- CgroupCpuMonitor() - Constructor for class org.apache.druid.java.util.metrics.CgroupCpuMonitor
- CgroupCpuMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.CgroupCpuMonitor
- CgroupCpuMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.CgroupCpuMonitor
- CgroupCpuMonitor(CgroupDiscoverer, Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.CgroupCpuMonitor
- CgroupCpuSetMonitor - Class in org.apache.druid.java.util.metrics
- CgroupCpuSetMonitor() - Constructor for class org.apache.druid.java.util.metrics.CgroupCpuSetMonitor
- CgroupCpuSetMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.CgroupCpuSetMonitor
- CgroupCpuSetMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.CgroupCpuSetMonitor
- CgroupCpuSetMonitor(CgroupDiscoverer, Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.CgroupCpuSetMonitor
- CgroupDiscoverer - Interface in org.apache.druid.java.util.metrics.cgroups
- CgroupMemoryMonitor - Class in org.apache.druid.java.util.metrics
- CgroupMemoryMonitor() - Constructor for class org.apache.druid.java.util.metrics.CgroupMemoryMonitor
- CgroupMemoryMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.CgroupMemoryMonitor
- CgroupMemoryMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.CgroupMemoryMonitor
- CgroupMemoryMonitor(CgroupDiscoverer, Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.CgroupMemoryMonitor
- CgroupUtil - Class in org.apache.druid.java.util.metrics
- CgroupUtil() - Constructor for class org.apache.druid.java.util.metrics.CgroupUtil
- 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(QueryProcessingPool, QueryWatcher, Iterable<QueryRunner<T>>) - Constructor for class org.apache.druid.query.ChainedExecutionQueryRunner
- ChannelResourceFactory - Class in org.apache.druid.java.util.http.client.pool
- ChannelResourceFactory(ClientBootstrap, SSLContext, HttpClientProxyConfig, Timer, long) - Constructor for class org.apache.druid.java.util.http.client.pool.ChannelResourceFactory
- Channels - Class in org.apache.druid.io
- checkAtMostOneNotNull(String, T, String, T) - Static method in class org.apache.druid.indexer.Checks
- checkAtMostOneNotNull(Property<T>, Property<T>) - Static method in class org.apache.druid.indexer.Checks
- checkedCast(int) - Static method in class org.apache.druid.common.utils.ByteUtils
- checkFileSize(File) - Static method in class org.apache.druid.segment.IndexIO
- checkFilterTuningUseIndex(String, ColumnIndexSelector, FilterTuning) - Static method in class org.apache.druid.segment.filter.Filters
- checkIndex(int) - Method in class org.apache.druid.segment.data.GenericIndexed
-
Checks if
index
a valid `element index` in GenericIndexed. - checkIndex(int, int) - Static method in interface org.apache.druid.segment.data.Indexed
-
Checks if
index
is between 0 andsize
. - checkInterrupted() - Static method in class org.apache.druid.query.BaseQuery
- checkMaxSize(int, int, TypeSignature<?>) - Static method in class org.apache.druid.segment.column.TypeStrategies
- checkModifiedFromOwnerThread() - Method in class org.apache.druid.query.DefaultQueryMetrics
- checkOneNotNullOrEmpty(List<Property<T>>) - Static method in class org.apache.druid.indexer.Checks
- checkPrefixesForDuplicatesAndShadowing(List<String>) - Static method in class org.apache.druid.segment.join.JoinPrefixUtils
-
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.FixedWidthGroupByColumnSelectorStrategy
-
This is used for multi-valued dimensions, for values after the first one.
- 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.KeyMappingMultiValueGroupByColumnSelectorStrategy
- Checks - Class in org.apache.druid.indexer
-
Various helper methods useful for checking the validity of arguments to spec constructors.
- CHECKSUM_SEED - Static variable in class org.apache.druid.frame.file.FrameFileWriter
- checkUnsortedEncodedKeyComponentsEqual(int[], int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
- 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(StructuredData, StructuredData) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- checkUnsortedEncodedKeyComponentsEqual(StructuredData, StructuredData) - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- checkValidAndBounds(long, long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- chop(String, int) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Returns the string truncated to maxBytes.
- chunkedCopy(InputStream, File) - Static method in class org.apache.druid.java.util.common.io.NativeIO
-
Copy from an input stream to a file minimizing cache impact on the destination..
- ChunkingStorageConnector<T> - Class in org.apache.druid.storage.remote
-
An abstract implementation of the storage connectors that download the file from the remote storage in chunks and presents the downloaded chunks as a single
InputStream
for the consumers of the connector. - ChunkingStorageConnector() - Constructor for class org.apache.druid.storage.remote.ChunkingStorageConnector
- ChunkingStorageConnector(long) - Constructor for class org.apache.druid.storage.remote.ChunkingStorageConnector
- ChunkingStorageConnector.GetObjectFromRangeFunction<T> - Interface in org.apache.druid.storage.remote
- ChunkingStorageConnectorParameters<T> - Class in org.apache.druid.storage.remote
-
POJO for storing the parameters required to support chunking of the downloads by
ChunkingStorageConnector
. - ChunkingStorageConnectorParameters(long, long, String, ChunkingStorageConnector.GetObjectFromRangeFunction<T>, ObjectOpenFunction<T>, Predicate<Throwable>, int, Supplier<File>) - Constructor for class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- ChunkingStorageConnectorParameters.Builder<T> - Class in org.apache.druid.storage.remote
-
Builder for
ChunkingStorageConnectorParameters
. - CircularBuffer<E> - Class in org.apache.druid.utils
-
A circular buffer that supports random bidirectional access.
- CircularBuffer(int) - Constructor for class org.apache.druid.utils.CircularBuffer
- classOfObject() - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
- classOfObject() - Method in class org.apache.druid.query.aggregation.cardinality.HyperLogLogCollectorAggregateCombiner
- classOfObject() - Method in class org.apache.druid.query.aggregation.firstlast.first.GenericFirstAggregateCombiner
- classOfObject() - Method in class org.apache.druid.query.aggregation.firstlast.last.GenericLastAggregateCombiner
- classOfObject() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
- classOfObject() - Method in interface org.apache.druid.segment.BaseObjectColumnValueSelector
-
Most-specific class of object returned by
BaseObjectColumnValueSelector.getObject()
, if known in advance. - 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 class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- 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.BaseExpressionColumnValueSelector
- classOfObject() - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
- classOfObject() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- classOfObject() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector
- classOfObject() - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- clean() - Method in interface org.apache.druid.java.util.common.Cleaners.Cleanable
- clean(QueryResourceId) - Method in class org.apache.druid.query.groupby.GroupByResourcesReservationPool
-
Removes the entry corresponding to the unique id from the map, and cleans up the resources.
- Cleaners - Class in org.apache.druid.java.util.common
- Cleaners() - Constructor for class org.apache.druid.java.util.common.Cleaners
- Cleaners.Cleanable - Interface in org.apache.druid.java.util.common
- Cleaners.Cleaner - Interface in org.apache.druid.java.util.common
- cleanup() - Method in class org.apache.druid.frame.processor.FrameChannelBatcher
- cleanup() - Method in class org.apache.druid.frame.processor.FrameChannelHashPartitioner
- cleanup() - Method in class org.apache.druid.frame.processor.FrameChannelMerger
- cleanup() - Method in class org.apache.druid.frame.processor.FrameChannelMixer
- cleanup() - Method in interface org.apache.druid.frame.processor.FrameProcessor
-
Closes resources used by this worker.
- cleanup() - Method in interface org.apache.druid.java.util.common.RetryUtils.CleanupAfterFailure
-
This is called once
RetryUtils.Task.perform()
fails. - cleanup(IterType) - Method in interface org.apache.druid.java.util.common.guava.BaseSequence.IteratorMaker
- cleanup(PooledTopNAlgorithm.PooledTopNParams) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
- cleanup(TopNParams) - Method in class org.apache.druid.query.topn.AggregateTopNMetricFirstAlgorithm
- cleanup(TopNParams) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
- 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.extendedset.intset.ConciseSet
- clear() - Method in class org.apache.druid.frame.allocation.AppendableMemory
- clear() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
-
Clear the table, resetting size to zero.
- clear() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- clear() - Method in class org.apache.druid.segment.data.SafeWritableMemory
- clear() - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
- clear(long, long) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- clearBits(long, byte) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- clearBitsAfterInLastWord(int, int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- clearEncodingFlag(byte) - Static method in class org.apache.druid.segment.data.CompressionFactory
- CliCommandCreator - Interface in org.apache.druid.cli
-
An extension point to create a custom Druid service.
- ClientResponse<T> - Class in org.apache.druid.java.util.http.client.response
- ClientResponse(boolean, boolean, T) - Constructor for class org.apache.druid.java.util.http.client.response.ClientResponse
- ClockDriftSafeMonitorScheduler - Class in org.apache.druid.java.util.metrics
-
A
MonitorScheduler
implementation based onCronScheduler
. - ClockDriftSafeMonitorScheduler(DruidMonitorSchedulerConfig, ServiceEmitter, List<Monitor>, CronScheduler, ExecutorService) - Constructor for class org.apache.druid.java.util.metrics.ClockDriftSafeMonitorScheduler
- 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.extendedset.intset.AbstractIntSet
-
See the
clone()
ofObject
- clone() - Method in class org.apache.druid.extendedset.intset.BitIterator
- clone() - Method in class org.apache.druid.extendedset.intset.ConciseSet
-
See the
clone()
ofObject
- clone() - Method in class org.apache.druid.extendedset.intset.EmptyIntIterator
- clone() - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet.WordIterator
- clone() - Method in interface org.apache.druid.extendedset.intset.IntSet
-
See the
clone()
ofObject
- clone() - Method in interface org.apache.druid.extendedset.intset.IntSet.IntIterator
-
Clone the iterator
- clone() - Method in class org.apache.druid.frame.segment.FrameFilteredOffset
-
See
FilteredOffset.clone()
for notes. - 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 ofFilter
. - 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
- cloneAggValue(AggregatorFactory, Object) - Static method in class org.apache.druid.query.rowsandcols.semantic.DefaultFramedOnHeapAggregatable
- cloneBitSet() - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
- close() - Method in class org.apache.druid.collections.CloseableResourceHolder
- close() - Method in class org.apache.druid.collections.ReferenceCountingResourceHolder
-
Decrements the reference count by 1.
- close() - Method in interface org.apache.druid.collections.ResourceHolder
- close() - Method in class org.apache.druid.collections.StupidResourceHolder
- close() - Method in interface org.apache.druid.data.input.Firehose
-
Deprecated.Closes the "ingestion side" of the Firehose, potentially concurrently with calls to
Firehose.hasMore()
andFirehose.nextRow()
being made from a different thread. - close() - Method in class org.apache.druid.data.input.HandlingInputRowIterator
- close() - Method in class org.apache.druid.data.input.impl.FastLineIterator
- close() - Method in class org.apache.druid.data.input.impl.prefetch.JsonIterator
- close() - Method in class org.apache.druid.data.input.impl.RetryingInputStream
- close() - Method in class org.apache.druid.frame.allocation.AppendableMemory
- close() - Method in class org.apache.druid.frame.channel.ComposingReadableFrameChannel
- close() - Method in class org.apache.druid.frame.channel.ComposingWritableFrameChannel
- close() - Method in class org.apache.druid.frame.channel.DurableStoragePartitionedReadableFrameChannel
- close() - Method in class org.apache.druid.frame.channel.FrameChannelSequence.FrameChannelIterator
- close() - Method in interface org.apache.druid.frame.channel.PartitionedReadableFrameChannel
-
Releases any resources associated with this readable channel.
- close() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
- close() - Method in class org.apache.druid.frame.channel.ReadableConcatFrameChannel
- close() - Method in class org.apache.druid.frame.channel.ReadableFileFrameChannel
- close() - Method in interface org.apache.druid.frame.channel.ReadableFrameChannel
-
Releases any resources associated with this readable channel.
- close() - Method in class org.apache.druid.frame.channel.ReadableInputStreamFrameChannel
- close() - Method in class org.apache.druid.frame.channel.ReadableNilFrameChannel
- close() - Method in interface org.apache.druid.frame.channel.WritableFrameChannel
-
Finish writing to this channel.
- close() - Method in class org.apache.druid.frame.channel.WritableFrameFileChannel
- close() - Method in class org.apache.druid.frame.field.ComplexFieldWriter
- close() - Method in interface org.apache.druid.frame.field.FieldWriter
-
Releases resources held by this writer.
- close() - Method in class org.apache.druid.frame.field.FloatFieldWriter
- close() - Method in class org.apache.druid.frame.field.NumericArrayFieldWriter
- close() - Method in class org.apache.druid.frame.field.NumericFieldWriter
- close() - Method in class org.apache.druid.frame.field.StringArrayFieldWriter
- close() - Method in class org.apache.druid.frame.field.StringFieldWriter
- close() - Method in class org.apache.druid.frame.file.FrameFile
- close() - Method in class org.apache.druid.frame.file.FrameFileWriter
- close() - Method in class org.apache.druid.frame.processor.manager.AccumulatingProcessorManager
- close() - Method in interface org.apache.druid.frame.processor.manager.ProcessorManager
-
Called when all processors are done, or when one has failed.
- close() - Method in class org.apache.druid.frame.processor.manager.SequenceProcessorManager
- close() - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader.NumericArrayFrameColumn
- close() - Method in class org.apache.druid.frame.segment.columnar.FrameQueryableIndex
- close() - Method in class org.apache.druid.frame.segment.columnar.FrameVectorCursor
- close() - Method in class org.apache.druid.frame.segment.FrameSegment
- close() - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriter
- close() - Method in class org.apache.druid.frame.write.columnar.ComplexFrameColumnWriter
- close() - Method in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- close() - Method in class org.apache.druid.frame.write.columnar.DoubleFrameColumnWriter
- close() - Method in class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- close() - Method in class org.apache.druid.frame.write.columnar.FloatFrameColumnWriter
- close() - Method in class org.apache.druid.frame.write.columnar.FloatFrameMaker
- close() - Method in interface org.apache.druid.frame.write.columnar.FrameColumnWriter
- close() - Method in class org.apache.druid.frame.write.columnar.LongFrameColumnWriter
- close() - Method in class org.apache.druid.frame.write.columnar.LongFrameMaker
- close() - Method in class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
- close() - Method in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
- close() - Method in interface org.apache.druid.frame.write.FrameWriter
- close() - Method in class org.apache.druid.frame.write.RowBasedFrameWriter
- close() - Method in class org.apache.druid.java.util.common.guava.ExecuteWhenDoneYielder
- close() - Method in class org.apache.druid.java.util.common.io.Closer
-
Closes all
Closeable
instances that have been added to thisCloser
. - close() - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher
- close() - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- close() - Method in class org.apache.druid.java.util.common.io.smoosh.SmooshedFileMapper
- close() - Method in class org.apache.druid.java.util.common.MappedByteBufferHandler
-
Unmaps the wrapped buffer.
- close() - Method in class org.apache.druid.java.util.emitter.core.ComposingEmitter
- close() - Method in interface org.apache.druid.java.util.emitter.core.Emitter
- close() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- close() - Method in class org.apache.druid.java.util.emitter.core.LoggingEmitter
- close() - Method in class org.apache.druid.java.util.emitter.core.NoopEmitter
- close() - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitter
- close() - Method in class org.apache.druid.java.util.emitter.core.SwitchingEmitter
-
Closes all emitters that the SwitchingEmitter uses
- close() - Method in class org.apache.druid.java.util.emitter.service.ServiceEmitter
- close() - Method in class org.apache.druid.java.util.http.client.pool.ResourcePool
- close() - Method in interface org.apache.druid.query.aggregation.Aggregator
- close() - Method in class org.apache.druid.query.aggregation.any.NilVectorAggregator
- 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.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.cardinality.CardinalityVectorAggregator
- close() - Method in class org.apache.druid.query.aggregation.constant.LongConstantAggregator
- close() - Method in class org.apache.druid.query.aggregation.constant.LongConstantBufferAggregator
- close() - Method in class org.apache.druid.query.aggregation.constant.LongConstantVectorAggregator
- 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.ExpressionLambdaAggregator
- close() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaBufferAggregator
- 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.firstlast.first.NumericFirstAggregator
- close() - Method in class org.apache.druid.query.aggregation.firstlast.first.NumericFirstBufferAggregator
- close() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- close() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- close() - Method in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
- close() - Method in class org.apache.druid.query.aggregation.firstlast.last.NumericLastAggregator
- close() - Method in class org.apache.druid.query.aggregation.firstlast.last.NumericLastBufferAggregator
- close() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- close() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- 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.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.SerializablePairLongDoubleComplexColumn
- close() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn
- close() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn
- close() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn
- 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.SingleValueAggregator
- close() - Method in class org.apache.druid.query.aggregation.SingleValueBufferAggregator
- 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.GroupByQueryResources
-
Closes the query resource.
- 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.rowsandcols.concrete.ColumnBasedFrameRowsAndColumns
- close() - Method in class org.apache.druid.query.rowsandcols.concrete.ColumnHolderRACColumn
- close() - Method in class org.apache.druid.query.rowsandcols.concrete.QueryableIndexRowsAndColumns
- close() - Method in class org.apache.druid.query.rowsandcols.concrete.RowBasedFrameRowsAndColumns
- close() - Method in class org.apache.druid.query.rowsandcols.StorageAdapterRowsAndColumns
- close() - Method in class org.apache.druid.query.scan.ScanQueryLimitRowIterator
- close() - Method in class org.apache.druid.query.scan.ScanResultValueIterator
- close() - Method in class org.apache.druid.segment.ArrayListSegment
- 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.StringUtf8DictionaryEncodedColumn
- close() - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
- 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.CompressedBlockReader
- close() - Method in class org.apache.druid.segment.data.CompressedLongsReader
- close() - Method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumn
- 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.DictionaryMergingIterator
- 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.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.IndexableAdapter.NestedColumnMergable
- close() - Method in class org.apache.druid.segment.join.HashJoinSegment
- close() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
- close() - Method in class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- 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 class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- close() - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- close() - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- close() - Method in class org.apache.druid.segment.nested.ScalarDoubleColumn
- close() - Method in class org.apache.druid.segment.nested.ScalarLongColumn
- close() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- close() - Method in class org.apache.druid.segment.nested.VariantColumn
- 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.RowWalker
- close() - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadBuffer
- close() - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadReader
- close() - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter
- close() - Method in class org.apache.druid.segment.serde.cell.CellIndexReader
- close() - Method in class org.apache.druid.segment.serde.cell.CellIndexWriter
- close() - Method in class org.apache.druid.segment.serde.cell.CellReader
- close() - Method in class org.apache.druid.segment.serde.cell.CellWriter
- close() - Method in class org.apache.druid.segment.serde.cell.IndexWriter
- close() - Method in interface org.apache.druid.segment.serde.cell.IOIterator
- close() - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarInts
- close() - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- close() - Method in class org.apache.druid.segment.SimpleDictionaryMergingIterator
- 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.WrappedSegmentReference
- 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.
- close(ChannelFuture) - Method in class org.apache.druid.java.util.http.client.pool.ChannelResourceFactory
- close(V) - Method in interface org.apache.druid.java.util.http.client.pool.ResourceFactory
- 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
- CloseableIterator<T> - Interface in org.apache.druid.java.util.common.parsers
- CloseableIterators - Class in org.apache.druid.java.util.common
- CloseableIteratorWithMetadata<T> - Interface in org.apache.druid.java.util.common.parsers
-
Like
CloseableIterator
, but has a currentMetadata() method, which returns "metadata", which is effectively a Mapabout the source of last value returned by next() The returned metadata is read-only and cannot be modified. - CloseableResourceHolder<T extends Closeable> - Class in org.apache.druid.collections
- CloseableShapeshifter - Interface in org.apache.druid.segment
-
A CloseableShapeshifter is an interface created to allow Segments to be used from
CloseableShapeshifter.as(Class)
, but also to be able to ensure that any resource used by the object returned from theCloseableShapeshifter.as(Class)
method have proper management of their lifecycle. - CloseableUtils - Class in org.apache.druid.utils
-
Methods in this class could have belonged to
Closer
, but not editing that class to keep its source close to Guava source. - 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 with the aggregates processor - closeAll(Closeable, Closeable...) - Static method in class org.apache.druid.utils.CloseableUtils
-
Call method instead of code like first.close(); second.close(); to have safety of
Closer
, but without associated boilerplate code of creating a Closer and registering objects in it. - closeAll(Iterable<T>) - Static method in class org.apache.druid.utils.CloseableUtils
-
Close all the provided {@param closeables}, from first to last.
- closeAll(List<ReadableFrameChannel>, List<WritableFrameChannel>, Closeable...) - Static method in class org.apache.druid.frame.processor.FrameProcessors
-
Helper method for implementing
FrameProcessor.cleanup()
. - closeAndSuppressExceptions(Closeable, Consumer<Throwable>) - Static method in class org.apache.druid.utils.CloseableUtils
-
Like
Closeable.close()
but sends any exceptions to the provided Consumer and then returns quietly. - closeAndWrapExceptions(Closeable) - Static method in class org.apache.druid.utils.CloseableUtils
-
Like
Closeable.close()
but wraps IOExceptions in RuntimeExceptions. - closeAndWrapInCatch(E, Closeable) - Static method in class org.apache.druid.utils.CloseableUtils
-
Like
CloseableUtils.closeInCatch(E, java.io.Closeable)
but wraps {@param caught} in aRuntimeException
if it is a checked exception. - CLOSED - org.apache.druid.query.filter.RangeFilter.RangeType
-
[...]
- closedForWrite - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- closeInCatch(E, Closeable) - Static method in class org.apache.druid.utils.CloseableUtils
-
Like
Closeable.close()
, but guaranteed to throw {@param caught}. - closer - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- closer - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- Closer - Class in org.apache.druid.java.util.common.io
- closeToSerializer() - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadBuffer
- CloudObjectInputSource - Class in org.apache.druid.data.input.impl
- CloudObjectInputSource(String, List<URI>, List<URI>, List<CloudObjectLocation>, String, SystemFields) - Constructor for class org.apache.druid.data.input.impl.CloudObjectInputSource
- CloudObjectLocation - Class in org.apache.druid.data.input.impl
-
Common type for 'bucket' and 'path' concept of cloud objects to allow code sharing between cloud specific implementations.
- CloudObjectLocation(String, String) - Constructor for class org.apache.druid.data.input.impl.CloudObjectLocation
- CloudObjectLocation(URI) - Constructor for class org.apache.druid.data.input.impl.CloudObjectLocation
- CloudObjectSplitWidget - Interface in org.apache.druid.data.input.impl
- CloudObjectSplitWidget.LocationWithSize - Class in org.apache.druid.data.input.impl
- cloudStoragePath(String) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- ClusterBy - Class in org.apache.druid.frame.key
-
Describes a key used for sorting or partitioning.
- ClusterBy(List<KeyColumn>, int) - Constructor for class org.apache.druid.frame.key.ClusterBy
- ClusterByPartition - Class in org.apache.druid.frame.key
-
Boundaries of a partition marked by start and end keys.
- ClusterByPartition(RowKey, RowKey) - Constructor for class org.apache.druid.frame.key.ClusterByPartition
- ClusterByPartitions - Class in org.apache.druid.frame.key
-
Holder object for a set of
ClusterByPartition
. - ClusterByPartitions(List<ClusterByPartition>) - Constructor for class org.apache.druid.frame.key.ClusterByPartitions
- ClusteredGroupPartitioner - Interface in org.apache.druid.query.rowsandcols.semantic
-
A semantic interface used to partition a data set based on a given set of columns.
- CNFFilterExplosionException - Exception in org.apache.druid.segment.filter.cnf
- CNFFilterExplosionException(String, Object...) - Constructor for exception org.apache.druid.segment.filter.cnf.CNFFilterExplosionException
- coalesce(List<ListenableFuture<T>>) - Static method in class org.apache.druid.common.guava.FutureUtils
-
Like
Futures.successfulAsList(com.google.common.util.concurrent.ListenableFuture<? extends V>...)
, but returnsEither
instead of usingnull
in case of error. - CoalesceFunc() - Constructor for class org.apache.druid.math.expr.Function.CoalesceFunc
- coerceElement(Object) - Method in class org.apache.druid.query.DimensionComparisonUtils.ArrayComparator
- coerceElement(Object) - Method in class org.apache.druid.query.DimensionComparisonUtils.ArrayComparatorForUnnaturalStringComparator
- coerceEvalToObjectOrList(ExprEval) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
-
Coerces
ExprEval
value back to aColumnType.STRING
selector friendly value, converting into: - the expression value if the value is not an array - the single array element if the value is an array with 1 element - a list with all of the array elements if the value is an array with more than 1 element This method is used byExpressionSelectors.makeStringColumnValueSelector(ColumnSelectorFactory, Expr)
, which is used exclusively for makingColumnValueSelector
when anExpressionVirtualColumn
has STRING output type, and byExpressionTransform
which should be reconsidered if we ever want to add support for ingestion transforms producingValueType.ARRAY
typed outputs. - coerceListToArray(List<?>, boolean) - Static method in class org.apache.druid.math.expr.ExprEval
-
Converts a List to an appropriate array type, optionally doing some conversion to make multi-valued strings consistent across selector types, which are not consistent in treatment of null, [], and [null].
- coerceToObjectArrayWithElementCoercionFunction(Object, Function<Object, Object>) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- coerceToStringArray(Object) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- coerceUnknownToBoolean(boolean) - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- coerceValue(String) - Method in class org.apache.druid.segment.StringDimensionMergerV9
- coerceValue(T) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- CollectionUtils - Class in org.apache.druid.utils
- cols - Variable in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns.Builder
- column(String) - Method in class org.apache.druid.frame.write.InvalidFieldException.Builder
- column(String) - Method in class org.apache.druid.frame.write.InvalidNullByteException.Builder
- Column - Interface in org.apache.druid.query.rowsandcols.column
-
An interface representing a Column of data.
- ColumnAccessor - Interface in org.apache.druid.query.rowsandcols.column
-
Allows for accessing a column, provides methods to enable row-by-row access of a specific column.
- ColumnAccessorBasedColumn - Class in org.apache.druid.query.rowsandcols.column
- ColumnAccessorBasedColumn(ColumnAccessor) - Constructor for class org.apache.druid.query.rowsandcols.column.ColumnAccessorBasedColumn
- ColumnAccessorBasedColumnSelectorFactory(AtomicInteger, RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultColumnSelectorFactoryMaker.ColumnAccessorBasedColumnSelectorFactory
- ColumnAnalysis - Class in org.apache.druid.query.metadata.metadata
- ColumnAnalysis(ColumnType, String, boolean, boolean, long, Integer, Comparable, Comparable, String) - Constructor for class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- ColumnAnalysis.Builder<T> - Class in org.apache.druid.query.metadata.metadata
- COLUMNAR - org.apache.druid.frame.FrameType
- 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
. - ColumnarFrameWriter - Class in org.apache.druid.frame.write.columnar
- ColumnarFrameWriter(RowSignature, List<KeyColumn>, AppendableMemory, List<FrameColumnWriter>) - Constructor for class org.apache.druid.frame.write.columnar.ColumnarFrameWriter
- ColumnarFrameWriterFactory - Class in org.apache.druid.frame.write.columnar
- ColumnarFrameWriterFactory(MemoryAllocatorFactory, RowSignature, List<KeyColumn>) - Constructor for class org.apache.druid.frame.write.columnar.ColumnarFrameWriterFactory
-
Create a ColumnarFrameWriterFactory.
- 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
orColumnarMultiInts
. - 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
- ColumnBasedFrameRowsAndColumns - Class in org.apache.druid.query.rowsandcols.concrete
- ColumnBasedFrameRowsAndColumns(Frame, RowSignature) - Constructor for class org.apache.druid.query.rowsandcols.concrete.ColumnBasedFrameRowsAndColumns
- ColumnBuilder - Class in org.apache.druid.segment.column
- ColumnBuilder() - Constructor for class org.apache.druid.segment.column.ColumnBuilder
- ColumnCache - Class in org.apache.druid.segment
- ColumnCache(QueryableIndex, Closer) - Constructor for class org.apache.druid.segment.ColumnCache
- columnCapabilities(Frame, String) - Method in class org.apache.druid.frame.read.FrameReader
-
Returns capabilities for a particular column in a particular frame.
- 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 defines the shape of a mechnism to allow for bespoke coercion of
ColumnCapabilities.Capable.UNKNOWN
intoColumnCapabilities.Capable.TRUE
orColumnCapabilities.Capable.FALSE
for eachColumnCapabilities.Capable
of aColumnCapabilities
, 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
-
Compares values between columns, first converting them all to strings.
- 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
- ColumnFormat - Interface in org.apache.druid.segment.column
- columnFunction(String) - Method in class org.apache.druid.data.input.ListBasedInputRowAdapter
- 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
- ColumnHolderRACColumn - Class in org.apache.druid.query.rowsandcols.concrete
-
Implements a RowsAndColumns column based on a ColumnHolder.
- ColumnHolderRACColumn(ColumnHolder) - Constructor for class org.apache.druid.query.rowsandcols.concrete.ColumnHolderRACColumn
- 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 class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- 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
- ColumnIndexCapabilities - Interface in org.apache.druid.segment.column
-
Sort of like
ColumnCapabilities
, except for indexes supplied byColumnIndexSelector
, provides information for how query processing may use indexes. - ColumnIndexSelector - Interface in org.apache.druid.query.filter
- ColumnIndexSupplier - Interface in org.apache.druid.segment.column
-
Provides indexes and information about them (
ColumnIndexCapabilities
) for a column. - ColumnInspector - Interface in org.apache.druid.segment
- columnName - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- columnName() - Method in class org.apache.druid.frame.key.KeyColumn
- columnNameBytes - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- ColumnPartSerde - Interface in org.apache.druid.segment.serde
- ColumnPartSerde.Deserializer - Interface in org.apache.druid.segment.serde
- ColumnPlus - Class in org.apache.druid.frame.read.columnar
- 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 class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- 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(String...) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- columns(List<String>) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- ColumnSelector - Interface in org.apache.druid.segment
- ColumnSelectorColumnIndexSelector - Class in org.apache.druid.segment
- ColumnSelectorColumnIndexSelector(BitmapFactory, VirtualColumns, ColumnSelector) - Constructor for class org.apache.druid.segment.ColumnSelectorColumnIndexSelector
- ColumnSelectorFactory - Interface in org.apache.druid.segment
-
Factory class for MetricSelectors
- ColumnSelectorFactoryMaker - Interface in org.apache.druid.query.rowsandcols.semantic
- 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
- ColumnsFilter - Class in org.apache.druid.data.input
-
Used by some
InputSourceReader
implementations in order to know what columns will need to be read out of theInputRow
objects they create. - ColumnsFilter() - Constructor for class org.apache.druid.data.input.ColumnsFilter
- ColumnsFilter.ExclusionBased - Class in org.apache.druid.data.input
- ColumnsFilter.InclusionBased - Class in org.apache.druid.data.input
- columnType - Variable in class org.apache.druid.query.filter.vector.ArrayVectorValueMatcher
- ColumnType - Class in org.apache.druid.segment.column
-
Native Druid types.
- ColumnType(ValueType, String, ColumnType) - Constructor for class org.apache.druid.segment.column.ColumnType
- ColumnTypeFactory - Class in org.apache.druid.segment.column
- columnTypes(List<ColumnType>) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- columnTypes(ColumnType...) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- 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.
- ColumnValueSwapper - Interface in org.apache.druid.query.rowsandcols.column
-
A semantic interface for use with
Column
objects. - ColumnValuesWithUniqueFlag(Set<String>, boolean) - Constructor for class org.apache.druid.segment.join.Joinable.ColumnValuesWithUniqueFlag
- ColumnWithDirection - Class in org.apache.druid.query.operator
- ColumnWithDirection(String, ColumnWithDirection.Direction) - Constructor for class org.apache.druid.query.operator.ColumnWithDirection
- ColumnWithDirection.Direction - Enum in org.apache.druid.query.operator
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
A method that knows how to combine the outputs of
Aggregator.get()
produced viaAggregatorFactory.factorize(org.apache.druid.segment.ColumnSelectorFactory)
orBufferAggregator.get(java.nio.ByteBuffer, int)
produced viaAggregatorFactory.factorizeBuffered(org.apache.druid.segment.ColumnSelectorFactory)
. - 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.ExpressionLambdaAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- combine(Object, Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- 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.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
-
Combine method would never be invoked as the broker sends the subquery to multiple segments and gather the results to a single value on which the single value aggregator is applied.
- 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.
- CombineFirstTwoEntriesIndexed<T> - Class in org.apache.druid.segment.serde
-
An
Indexed
that delegates to an underyling instance, but combines the first two entries. - CombineFirstTwoEntriesIndexed(Indexed<T>) - Constructor for class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
- CombineFirstTwoValuesColumnarInts - Class in org.apache.druid.segment.serde
-
A
ColumnarInts
facade overCombineFirstTwoValuesIndexedInts
. - CombineFirstTwoValuesColumnarInts(ColumnarInts) - Constructor for class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarInts
- CombineFirstTwoValuesColumnarMultiInts - Class in org.apache.druid.segment.serde
-
A
ColumnarMultiInts
that delegates to an underyling instance, but appliesCombineFirstTwoValuesIndexedInts
to each row's set of values. - CombineFirstTwoValuesColumnarMultiInts(ColumnarMultiInts) - Constructor for class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- CombineFirstTwoValuesIndexedInts - Class in org.apache.druid.segment.serde
-
A
IndexedInts
that delegates to an underyling instance, but combines the values 0 and 1 into 0, and shifts all other values down by one. - CombineFirstTwoValuesIndexedInts(IndexedInts) - Constructor for class org.apache.druid.segment.serde.CombineFirstTwoValuesIndexedInts
- CombiningInputSource - Class in org.apache.druid.data.input.impl
-
InputSource that combines data from multiple inputSources.
- CombiningInputSource(List<SplittableInputSource>) - Constructor for class org.apache.druid.data.input.impl.CombiningInputSource
- CombiningIterable<T> - Class in org.apache.druid.collections
- CombiningIterable(Iterable<T>, Comparator<T>, BinaryOperator<T>) - Constructor for class org.apache.druid.collections.CombiningIterable
- CombiningIterator<T> - Class in org.apache.druid.collections
- CombiningIterator(Iterator<T>, Comparator<T>, BinaryOperator<T>) - Constructor for class org.apache.druid.collections.CombiningIterator
- CombiningSequence<T> - Class in org.apache.druid.common.guava
- COMMA_MATCH - Static variable in class org.apache.druid.java.util.metrics.CgroupUtil
- CommaListJoinDeserializer - Class in org.apache.druid.jackson
- CommaListJoinDeserializer() - Constructor for class org.apache.druid.jackson.CommaListJoinDeserializer
- CommaListJoinSerializer - Class in org.apache.druid.jackson
- CommaListJoinSerializer() - Constructor for class org.apache.druid.jackson.CommaListJoinSerializer
- commaSeparatedIdentifiers(Collection<DataSegment>) - Static method in class org.apache.druid.segment.SegmentUtils
-
Returns an object whose toString() returns a String with identifiers of the given segments, comma-separated.
- Committer - Interface in org.apache.druid.data.input
-
Committer includes a Runnable and a Jackson-serialized metadata object containing the offset
- COMMON_DATE_TIME_PATTERN - Static variable in class org.apache.druid.java.util.common.DateTimes
-
This pattern aims to match strings, produced by
AbstractDateTime.toString()
. - compact(ImmutableConciseSet) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- CompactionState - Class in org.apache.druid.timeline
-
This class describes what compaction task spec was used to create a given segment.
- CompactionState(PartitionsSpec, DimensionsSpec, List<Object>, Map<String, Object>, Map<String, Object>, Map<String, Object>) - Constructor for class org.apache.druid.timeline.CompactionState
- comparator() - Method in class org.apache.druid.collections.RangeIntSet
- COMPARATOR - Static variable in class org.apache.druid.query.aggregation.DoubleSumAggregator
- COMPARATOR - Static variable in class org.apache.druid.query.aggregation.FloatSumAggregator
- COMPARATOR - Static variable in class org.apache.druid.query.aggregation.LongSumAggregator
- COMPARATOR - Static variable in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
- COMPARATOR - Static variable in class org.apache.druid.query.topn.AlphaNumericTopNMetricSpec
- COMPARATOR - Static variable in class org.apache.druid.segment.nested.StructuredData
- ComparatorDimensionDictionary<T> - Class in org.apache.druid.segment
-
Comparator
basedDimensionDictionary
there are a lot of unused methods in here for now since the only thing this is used for is to build up the unsorted dictionary and then it is converted to aComparatorSortedDimensionDictionary
, but leaving the unused methods in place for now to be basically compatible with the other implementation. - ComparatorDimensionDictionary(Comparator<T>) - Constructor for class org.apache.druid.segment.ComparatorDimensionDictionary
- Comparators - Class in org.apache.druid.java.util.common.guava
- Comparators() - Constructor for class org.apache.druid.java.util.common.guava.Comparators
- ComparatorSortedDimensionDictionary<T> - Class in org.apache.druid.segment
-
Comparator
basedSortedDimensionDictionary
There are a number of unused methods, because nested columns don't merge bitmap indexes during the merge phase, rather they are created when serializing the column, but leaving for now for compatibility with the other implementation - ComparatorSortedDimensionDictionary(List<T>, Comparator<T>, int) - Constructor for class org.apache.druid.segment.ComparatorSortedDimensionDictionary
- compare(byte[], byte[]) - Method in class org.apache.druid.frame.key.ByteRowKeyComparator
- compare(int, FrameComparisonWidget, int) - Method in interface org.apache.druid.frame.key.FrameComparisonWidget
-
Compare a specific row of this frame to a specific row of another frame.
- compare(int, FrameComparisonWidget, int) - Method in class org.apache.druid.frame.key.FrameComparisonWidgetImpl
- compare(int, RowKey) - Method in interface org.apache.druid.frame.key.FrameComparisonWidget
-
Compare a specific row of this frame to the provided key.
- compare(int, RowKey) - Method in class org.apache.druid.frame.key.FrameComparisonWidgetImpl
- compare(Object[], Object[]) - Method in class org.apache.druid.query.DimensionComparisonUtils.ArrayComparator
- compare(Object, Object) - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- compare(Object, Object) - Method in class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
- compare(Object, Object) - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- compare(Object, Object) - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- compare(Object, Object) - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- compare(Object, Object) - Method in class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- 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.NaturalComparator
- 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(ByteBuffer, ByteBuffer, int, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.BufferComparator
- 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
- compare(RowKey, RowKey) - Method in class org.apache.druid.frame.key.RowKeyComparator
- 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(T, T) - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- COMPARE_DATE_AS_STRING_MAX - Static variable in class org.apache.druid.java.util.common.DateTimes
- COMPARE_DATE_AS_STRING_MIN - Static variable in class org.apache.druid.java.util.common.DateTimes
- compareAndSwap(List<MetadataCASUpdate>) - Method in interface org.apache.druid.metadata.MetadataStorageConnector
-
Atomic compare-and-swap variant of insertOrUpdate().
- compareAndSwapLong(long, long, long) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- compareByteArraysUnsigned(byte[], int, int, byte[], int, int) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
-
Compares two byte arrays using unsigned byte ordering.
- compareComplexTypes(byte[], int, byte[], int, ColumnType, ComplexMetricSerde) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
- compareComplexTypes(Memory, long, byte[], int, ColumnType, ComplexMetricSerde) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
- compareComplexTypes(Memory, long, Memory, long, ColumnType, ComplexMetricSerde) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
- compareMemoryToByteArrayUnsigned(Memory, long, long, byte[], int, int) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
-
Compares Memory with a byte array using unsigned byte ordering.
- compareMemoryUnsigned(Memory, long, int, Memory, long, int) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
-
Compares two Memory ranges using unsigned byte ordering.
- compareObjectsAsType(Object, Object, ColumnType) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- compareRows(int, int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- compareRows(int, int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.DoubleColumnAccessorBase
- compareRows(int, int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.FloatColumnAccessorBase
- compareRows(int, int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.LongColumnAccessorBase
- compareRows(int, int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- compareRows(int, int) - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Compares two rows using a comparison that follows the same semantics as
Comparator.compare(T, T)
- compareRows(int, int) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- compareTo(long, long, Buffer, long, long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- compareTo(long, long, Memory, long, long) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- compareTo(ImmutableRTree) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
- compareTo(Row) - Method in class org.apache.druid.data.input.ListBasedInputRow
- compareTo(Row) - Method in class org.apache.druid.data.input.MapBasedRow
- compareTo(Row) - Method in class org.apache.druid.segment.transform.TransformedInputRow
- compareTo(StringTuple) - Method in class org.apache.druid.data.input.StringTuple
- compareTo(IntSet) - Method in class org.apache.druid.extendedset.intset.AbstractIntSet
- compareTo(IntSet) - Method in class org.apache.druid.extendedset.intset.ConciseSet
- compareTo(HyperLogLogCollector) - Method in class org.apache.druid.hll.HyperLogLogCollector
- 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(StructuredData) - Method in class org.apache.druid.segment.nested.StructuredData
- compareTo(TimeAndDimsPointer) - Method in class org.apache.druid.segment.TimeAndDimsPointer
-
Compares time column value and dimension column values, but not metric column values.
- compareTo(DataSegment) - Method in class org.apache.druid.timeline.DataSegment
- compareTo(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- compareTo(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.LinearPartitionChunk
- compareTo(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- compareTo(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- compareTo(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.The ordering of PartitionChunks is determined entirely by the partition boundaries and has nothing to do with the object.
- compareTo(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- compareTo(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- compareTo(SegmentId) - Method in class org.apache.druid.timeline.SegmentId
- compareTo(SegmentStatusInCluster) - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- compareUnicode(String, String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Compares two Java Strings in Unicode code-point order.
- compareUnsortedEncodedKeyComponents(int[], int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
- 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(StructuredData, StructuredData) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- compareUnsortedEncodedKeyComponents(StructuredData, StructuredData) - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- compareUtf8(byte[], byte[]) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Compares two UTF-8 byte strings in Unicode code-point order.
- compareUtf8ByteBuffers(ByteBuffer, ByteBuffer) - Static method in class org.apache.druid.java.util.common.ByteBufferUtils
-
Compares two ByteBuffers from their positions to their limits using ordering consistent with
String.compareTo(String)
. - compareUtf8UsingJavaStringOrdering(byte[], byte[]) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Compares two UTF-8 byte strings in UTF-16 code-unit order.
- compareUtf8UsingJavaStringOrdering(byte, byte) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Compares two bytes from UTF-8 strings in such a way that the entire byte arrays are compared in UTF-16 code-unit order.
- compareUtf8UsingJavaStringOrdering(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Compares two UTF-8 byte strings in UTF-16 code-unit order.
- 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(ImmutableBitmap, int) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
- complement(ImmutableConciseSet) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- complement(ImmutableConciseSet, int) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- 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. - complete() - Method in interface org.apache.druid.query.rowsandcols.semantic.NaiveSortMaker.NaiveSorter
-
Indicate that there is no more data coming.
- complete(ObjectMapper, int, int) - Method in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- complete(ObjectMapper, int, int) - Method in class org.apache.druid.timeline.partition.LinearPartialShardSpec
- complete(ObjectMapper, int, int) - Method in class org.apache.druid.timeline.partition.NumberedOverwritePartialShardSpec
- complete(ObjectMapper, int, int) - Method in class org.apache.druid.timeline.partition.NumberedPartialShardSpec
- complete(ObjectMapper, int, int) - Method in interface org.apache.druid.timeline.partition.PartialShardSpec
-
Creates a new ShardSpec with given partitionId and numCorePartitions.
- complete(ObjectMapper, int, int) - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- COMPLETE - org.apache.druid.metadata.TaskLookup.TaskLookupType
- completed() - Method in interface org.apache.druid.query.operator.Operator.Receiver
-
Used to indicate that no more data will ever come.
- COMPLETED - org.apache.druid.indexer.IngestionState
- CompleteTaskLookup(Integer, DateTime) - Constructor for class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- COMPLEX - org.apache.druid.math.expr.ExprType
- COMPLEX - org.apache.druid.segment.column.ValueType
-
Placeholder for arbitrary 'complex' types, which have a corresponding serializer/deserializer implementation.
- COMPLEX - org.apache.druid.segment.MetricHolder.MetricType
- COMPLEX_STRATEGIES - Static variable in class org.apache.druid.segment.column.TypeStrategies
- 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 inComplexColumnSerializer
. - 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
- ComplexDecodeBase64ExprMacro() - Constructor for class org.apache.druid.math.expr.BuiltInExprMacros.ComplexDecodeBase64ExprMacro
- ComplexFieldReader - Class in org.apache.druid.frame.field
-
Reads values written by
ComplexFieldWriter
. - ComplexFieldWriter - Class in org.apache.druid.frame.field
-
Wraps a
BaseObjectColumnValueSelector
and usesComplexMetricSerde.toBytes(java.lang.Object)
to write complex objects. - ComplexFrameColumnReader - Class in org.apache.druid.frame.read.columnar
- ComplexFrameColumnWriter - Class in org.apache.druid.frame.write.columnar
-
Column writer for complex columns.
- ComplexFrameMaker - Class in org.apache.druid.frame.write.columnar
-
Column writer for complex columns.
- 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
- complexTypeName - Variable in class org.apache.druid.segment.column.BaseTypeSignature
- COMPONENT_FAILURE - org.apache.druid.java.util.emitter.service.AlertEvent.Severity
- ComposingEmitter - Class in org.apache.druid.java.util.emitter.core
- ComposingEmitter(List<Emitter>) - Constructor for class org.apache.druid.java.util.emitter.core.ComposingEmitter
- ComposingOutputChannelFactory - Class in org.apache.druid.frame.processor
-
A channel factory which provides ordered composed channels.
- ComposingOutputChannelFactory(List<OutputChannelFactory>, int) - Constructor for class org.apache.druid.frame.processor.ComposingOutputChannelFactory
- ComposingProcessor - Class in org.apache.druid.query.operator.window
- ComposingProcessor(Processor...) - Constructor for class org.apache.druid.query.operator.window.ComposingProcessor
- ComposingReadableFrameChannel - Class in org.apache.druid.frame.channel
-
A composed readable channel to read frames.
- ComposingReadableFrameChannel(int, List<Supplier<ReadableFrameChannel>>, HashSet<Integer>) - Constructor for class org.apache.druid.frame.channel.ComposingReadableFrameChannel
- ComposingWritableFrameChannel - Class in org.apache.druid.frame.channel
-
A composed writable channel to write frames.
- ComposingWritableFrameChannel(List<Supplier<OutputChannel>>, List<Supplier<PartitionedOutputChannel>>, List<Supplier<WritableFrameChannel>>, Map<Integer, HashSet<Integer>>) - Constructor for class org.apache.druid.frame.channel.ComposingWritableFrameChannel
- CompoundMonitor - Class in org.apache.druid.java.util.metrics
- CompoundMonitor(List<Monitor>) - Constructor for class org.apache.druid.java.util.metrics.CompoundMonitor
- CompoundMonitor(Monitor...) - Constructor for class org.apache.druid.java.util.metrics.CompoundMonitor
- 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
- compress(ByteBuffer, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.ZstdCompressor
- COMPRESSED - org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.VERSION
- COMPRESSED_FRAME_ENVELOPE_SIZE - Static variable in class org.apache.druid.frame.Frame
- COMPRESSED_FRAME_HEADER_SIZE - Static variable in class org.apache.druid.frame.Frame
- COMPRESSED_FRAME_TRAILER_SIZE - Static variable in class org.apache.druid.frame.Frame
- COMPRESSED_TEXT_WEIGHT_FACTOR - Static variable in class org.apache.druid.utils.CompressionUtils
- CompressedBlockReader - Class in org.apache.druid.segment.data
-
Reader for a virtual contiguous address range backed by compressed blocks of data.
- CompressedBlockReader(CompressionStrategy, int, int, IntBuffer, ByteBuffer, ByteOrder) - Constructor for class org.apache.druid.segment.data.CompressedBlockReader
- CompressedBlockSerializer - Class in org.apache.druid.segment.data
- CompressedBlockSerializer(SegmentWriteOutMedium, CompressionStrategy, int, Closer) - Constructor for class org.apache.druid.segment.data.CompressedBlockSerializer
- compressedByteBuffersWriteObjectStrategy(CompressionStrategy, int, Closer) - Static method in class org.apache.druid.segment.data.GenericIndexedWriter
- 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
- CompressedLongsReader - Class in org.apache.druid.segment.data
- CompressedLongsReader(CompressedBlockReader) - Constructor for class org.apache.druid.segment.data.CompressedLongsReader
- CompressedLongsSerializer - Class in org.apache.druid.segment.data
- CompressedLongsSerializer(SegmentWriteOutMedium, CompressionStrategy, Closer) - Constructor for class org.apache.druid.segment.data.CompressedLongsSerializer
- CompressedNestedDataComplexColumn<TStringDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.nested
-
Implementation of
NestedDataComplexColumn
which uses aCompressedVariableSizedBlobColumn
for the 'raw'StructuredData
values and provides selectors for nested field columns specified by ordered lists ofNestedPathPart
. - CompressedNestedDataComplexColumn(String, ColumnType, ColumnConfig, CompressedVariableSizedBlobColumnSupplier, ImmutableBitmap, GenericIndexed<String>, FieldTypeInfo, Supplier<TStringDictionary>, Supplier<FixedIndexed<Long>>, Supplier<FixedIndexed<Double>>, Supplier<FrontCodedIntArrayIndexed>, SmooshedFileMapper, BitmapSerdeFactory, ByteOrder, String) - Constructor for class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- CompressedPools - Class in org.apache.druid.segment
- CompressedPools() - Constructor for class org.apache.druid.segment.CompressedPools
- CompressedVariableSizedBlobColumn - Class in org.apache.druid.segment.data
- CompressedVariableSizedBlobColumn(int, CompressedLongsReader, CompressedBlockReader) - Constructor for class org.apache.druid.segment.data.CompressedVariableSizedBlobColumn
- CompressedVariableSizedBlobColumnSerializer - Class in org.apache.druid.segment.data
- CompressedVariableSizedBlobColumnSerializer(String, SegmentWriteOutMedium, CompressionStrategy) - Constructor for class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSerializer
- CompressedVariableSizedBlobColumnSupplier - Class in org.apache.druid.segment.data
- CompressedVariableSizedBlobColumnSupplier(ByteBuffer, ByteBuffer, ByteOrder, int) - Constructor for class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSupplier
- 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
- compressionBufferSize(long) - Static method in class org.apache.druid.frame.Frame
-
Minimum size of compression buffer required by
Frame.writeTo(java.nio.channels.WritableByteChannel, boolean, java.nio.ByteBuffer, org.apache.druid.frame.channel.ByteTracker)
when "compress" is true. - CompressionFactory - Class in org.apache.druid.segment.data
-
Compression of metrics is done by using a combination of
CompressionStrategy
and Encoding(such asCompressionFactory.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
- CompressionStrategy.ZstdCompressor - Class in org.apache.druid.segment.data
- CompressionStrategy.ZstdDecompressor - Class in org.apache.druid.segment.data
- CompressionUtils - Class in org.apache.druid.utils
- CompressionUtils() - Constructor for class org.apache.druid.utils.CompressionUtils
- CompressionUtils.Format - Enum in org.apache.druid.utils
- Compressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.Compressor
- compute(int) - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector.LruEvalCache
- compute(long) - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector.LruEvalCache
- 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
- computeAggregatorsMap(List<AggregatorFactory>) - Static method in class org.apache.druid.query.groupby.having.HavingSpecUtil
- computeBaseAndPostUnnestFilters(Filter, Filter, VirtualColumns, String, ColumnCapabilities) - Method in class org.apache.druid.segment.UnnestStorageAdapter
-
Split queryFilter into pre- and post-correlate filters.
- computeBitmapResult(BitmapResultFactory<T>, boolean) - Method in class org.apache.druid.segment.index.AllFalseBitmapColumnIndex
- computeBitmapResult(BitmapResultFactory<T>, boolean) - Method in class org.apache.druid.segment.index.AllTrueBitmapColumnIndex
- computeBitmapResult(BitmapResultFactory<T>, boolean) - Method in class org.apache.druid.segment.index.AllUnknownBitmapColumnIndex
- computeBitmapResult(BitmapResultFactory<T>, boolean) - Method in interface org.apache.druid.segment.index.BitmapColumnIndex
-
Compute a bitmap result wrapped with the
BitmapResultFactory
representing the rows matched by this index. - computeBitmapResult(BitmapResultFactory<T>, boolean) - Method in class org.apache.druid.segment.index.SimpleImmutableBitmapDelegatingIterableIndex
- computeBitmapResult(BitmapResultFactory<T>, boolean) - Method in class org.apache.druid.segment.index.SimpleImmutableBitmapIndex
- computeBitmapResult(BitmapResultFactory<T>, boolean) - Method in class org.apache.druid.segment.index.SimpleImmutableBitmapIterableIndex
- computeBitmapResult(BitmapResultFactory<T>, int, int, boolean) - Method in interface org.apache.druid.segment.index.BitmapColumnIndex
-
Compute a bitmap result wrapped with the
BitmapResultFactory
representing the rows matched by this index, or null if the index cannot (or should not) be computed. - computeBitmapResult(BitmapResultFactory<T>, int, int, boolean) - Method in class org.apache.druid.segment.index.DictionaryRangeScanningBitmapIndex
- computeBitmapResult(BitmapResultFactory<T>, int, int, boolean) - Method in class org.apache.druid.segment.index.DictionaryScanningBitmapIndex
- computeBoundaries(List<String>) - Method in interface org.apache.druid.query.rowsandcols.semantic.ClusteredGroupPartitioner
-
Computes and returns a list of contiguous boundaries for independent groups.
- computeBoundaries(List<String>) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultClusteredGroupPartitioner
- computeCacheKey() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
- computeCacheKey() - Method in interface org.apache.druid.segment.join.table.IndexedTable
-
Computes a
byte[]
key for the table that can be used for computing cache keys for join operations. - computeCacheKey() - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
- computeCacheKey() - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
- computeCacheKey(QueryType) - Method in interface org.apache.druid.query.CacheStrategy
-
Computes the per-segment cache key for the given query.
- computeDefaultBitmapResults(Filter, ColumnIndexSelector) - Static method in class org.apache.druid.segment.filter.Filters
- computeEquiconditionsFromJoinableClauses() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis.Builder
- computeFilenameBytes() - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- computeFirstFieldPosition(int) - Static method in class org.apache.druid.frame.key.ByteRowKeyComparator
-
Compute the offset into each key where the first field starts.
- computeGroupings(List<String>) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultGroupPartitioner
- computeGroupings(List<String>) - Method in interface org.apache.druid.query.rowsandcols.semantic.GroupPartitioner
-
Computes the groupings of the underlying rows based on the columns passed in for grouping.
- computeIntSize(int) - Static method in class org.apache.druid.segment.data.VByte
-
Compute number of bytes required to represent variable byte encoded integer.
- computeJoinCacheKey(DataSource, JoinConditionAnalysis) - Method in interface org.apache.druid.segment.join.JoinableFactory
-
Compute the cache key for a data source participating in join operation.
- computeJoinCacheKey(DataSource, JoinConditionAnalysis) - Method in class org.apache.druid.segment.join.MapJoinableFactory
- 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.
- computeNewLength(int[], int, int) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
- 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.
- computeNumber(String) - Static method in class org.apache.druid.math.expr.ExprEval
- computeOffset(long, DateTimeZone) - Method in class org.apache.druid.query.TimewarpOperator
-
Map time t into the last `period` ending within `dataInterval`
- computeOnHeapSize() - Method in class org.apache.druid.segment.DimensionDictionary
-
Whether on-heap size of this dictionary should be computed.
- computeOnHeapSize() - Method in class org.apache.druid.segment.StringDimensionDictionary
- 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. - computeProcessorQuota(long, long) - Static method in class org.apache.druid.java.util.metrics.CgroupCpuMonitor
-
Calculates the total cores allocated through quotas.
- computeRequiredColumns(VirtualColumns, DimFilter, List<DimensionSpec>, List<AggregatorFactory>, List<String>) - Static method in class org.apache.druid.query.Queries
-
Helper for implementations of
Query.getRequiredColumns()
. - 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
- concat(Iterable<Sequence<T>>) - Static method in class org.apache.druid.java.util.common.guava.Sequences
- concat(List<? extends CloseableIterator<? extends T>>) - Static method in class org.apache.druid.java.util.common.CloseableIterators
- concat(Sequence<? extends Sequence<T>>) - Static method in class org.apache.druid.java.util.common.guava.Sequences
- concat(Sequence<T>...) - Static method in class org.apache.druid.java.util.common.guava.Sequences
- concat(Expr.VectorInputBindingInspector, List<Expr>) - Static method in class org.apache.druid.math.expr.vector.VectorStringProcessors
- concat(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorStringProcessors
- ConcatFunc() - Constructor for class org.apache.druid.math.expr.Function.ConcatFunc
- ConcatQueryRunner<T> - Class in org.apache.druid.query
- ConcatQueryRunner(Sequence<QueryRunner<T>>) - Constructor for class org.apache.druid.query.ConcatQueryRunner
- ConcatRowsAndColumns - Class in org.apache.druid.query.rowsandcols
-
A RowsAndColumns implementation that effectively concatenates multiple RowsAndColumns objects together.
- ConcatRowsAndColumns(ArrayList<RowsAndColumns>) - Constructor for class org.apache.druid.query.rowsandcols.ConcatRowsAndColumns
- ConcatSequence<T> - Class in org.apache.druid.java.util.common.guava
- ConcatSequence(Sequence<? extends Sequence<? extends T>>) - Constructor for class org.apache.druid.java.util.common.guava.ConcatSequence
- 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
- ConciseSet - Class in org.apache.druid.extendedset.intset
-
This is CONCISE: COmpressed 'N' Composable Integer SEt.
- ConciseSet() - Constructor for class org.apache.druid.extendedset.intset.ConciseSet
-
Creates an empty integer set
- ConciseSet(boolean) - Constructor for class org.apache.druid.extendedset.intset.ConciseSet
-
Creates an empty integer set
- ConciseSet(int[], boolean) - Constructor for class org.apache.druid.extendedset.intset.ConciseSet
- ConciseSetUtils - Class in org.apache.druid.extendedset.intset
- ConciseSetUtils() - Constructor for class org.apache.druid.extendedset.intset.ConciseSetUtils
- ConcurrentAwaitableCounter - Class in org.apache.druid.concurrent
-
This synchronization object allows to
ConcurrentAwaitableCounter.increment()
a counter without blocking, potentially from multiple threads (although in some use cases there is just one incrementer thread), and block in other thread(s), awaiting when the count reaches the provided value: seeConcurrentAwaitableCounter.awaitCount(long)
, or the specified number of events since the call: seeConcurrentAwaitableCounter.awaitNextIncrements(long)
. - ConcurrentAwaitableCounter() - Constructor for class org.apache.druid.concurrent.ConcurrentAwaitableCounter
- 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
- ConcurrentResponseContext - Class in org.apache.druid.query.context
-
The implementation of
ResponseContext
with aConcurrentHashMap
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
- ConcurrentTimeCounter - Class in org.apache.druid.java.util.emitter.core
-
A class to accumulate simple stats of some time points.
- ConcurrentTimeCounter() - Constructor for class org.apache.druid.java.util.emitter.core.ConcurrentTimeCounter
- condensedAggregators(List<AggregatorFactory>, List<PostAggregator>, String) - Static method in class org.apache.druid.query.aggregation.AggregatorUtil
- condensedIntervalsIterator(Iterator<Interval>) - Static method in class org.apache.druid.java.util.common.JodaUtils
-
Condense the provided intervals such that the returned list has no abutting intervals, no overlapping intervals, and no zero-length intervals.
- condenseIntervals(Iterable<Interval>) - Static method in class org.apache.druid.java.util.common.JodaUtils
-
Condense the provided intervals such that the returned list has no abutting intervals, no overlapping intervals, and no zero-length intervals.
- conditional(Expr.InputBindingInspector, List<Expr>) - Static method in class org.apache.druid.math.expr.ExpressionTypeConversion
-
Infer the output type of a list of possible 'conditional' expression outputs (where any of these could be the output expression if the corresponding case matching expression evaluates to true)
- ConditionalMultibind<T> - Class in org.apache.druid.guice
-
Provides the ability to conditionally bind an item to a set.
- ConditionalMultibind(Properties, Multibinder<T>) - Constructor for class org.apache.druid.guice.ConditionalMultibind
- ConditionFunc() - Constructor for class org.apache.druid.math.expr.Function.ConditionFunc
- config() - Method in class org.apache.druid.guice.ExtensionsLoader
- Config - Class in org.apache.druid.java.util.common.config
- Config() - Constructor for class org.apache.druid.java.util.common.config.Config
- CONFIG_TABLE_KEY_COLUMN - Static variable in interface org.apache.druid.metadata.MetadataStorageConnector
- CONFIG_TABLE_VALUE_COLUMN - Static variable in interface org.apache.druid.metadata.MetadataStorageConnector
- ConfigManager - Class in org.apache.druid.common.config
- ConfigManager(MetadataStorageConnector, Supplier<MetadataStorageTablesConfig>, Supplier<ConfigManagerConfig>) - Constructor for class org.apache.druid.common.config.ConfigManager
- ConfigManager.SetResult - Class in org.apache.druid.common.config
- ConfigManagerConfig - Class in org.apache.druid.common.config
- ConfigManagerConfig() - Constructor for class org.apache.druid.common.config.ConfigManagerConfig
- ConfigModule - Class in org.apache.druid.guice
- ConfigModule() - Constructor for class org.apache.druid.guice.ConfigModule
- ConfigProvider<T> - Class in org.apache.druid.guice
-
Deprecated.
- ConfigProvider(Class<T>, Map<String, String>) - Constructor for class org.apache.druid.guice.ConfigProvider
-
Deprecated.
- Configs - Class in org.apache.druid.common.config
-
Utility class for common config operations.
- Configs() - Constructor for class org.apache.druid.common.config.Configs
- ConfigSerde<T> - Interface in org.apache.druid.common.config
- configurate(Properties, String, Class<T>) - Method in class org.apache.druid.guice.JsonConfigurator
- configurate(Properties, String, Class<T>, Class<? extends T>) - Method in class org.apache.druid.guice.JsonConfigurator
- configure(Binder) - Method in class org.apache.druid.guice.ConfigModule
- configure(Binder) - Method in class org.apache.druid.guice.DruidGuiceExtensions
- configure(Binder) - Method in class org.apache.druid.guice.DruidSecondaryModule
- configure(Binder) - Method in class org.apache.druid.guice.ExpressionModule
- configure(Binder) - Method in class org.apache.druid.guice.ExtensionsModule
- configure(Binder) - Method in class org.apache.druid.guice.ExtensionsModule.SecondaryModule
- configure(Binder) - Method in class org.apache.druid.guice.JacksonConfigManagerModule
- configure(Binder) - Method in class org.apache.druid.guice.LifecycleModule
- configure(Binder) - Method in class org.apache.druid.guice.NestedDataModule
- 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.initialization.TombstoneDataStorageModule
- configure(Binder) - Method in class org.apache.druid.jackson.JacksonModule
- configure(Binder) - Method in class org.apache.druid.math.expr.ExpressionProcessingModule
- configure(Binder) - Method in class org.apache.druid.segment.writeout.SegmentWriteOutMediumModule
- configure(Binder) - Method in class org.apache.druid.storage.StorageConnectorModule
- configure(Injector) - Method in class org.apache.druid.guice.ProviderBasedGoogleSupplierProvider
- configure(JacksonConfigManager) - Method in class org.apache.druid.guice.JacksonConfigProvider
- 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.
- connect(T) - Method in interface org.apache.druid.data.input.FirehoseFactory
-
Deprecated.
- connect(T, File) - Method in interface org.apache.druid.data.input.FirehoseFactory
-
Deprecated.Initialization method that connects up the fire hose.
- ConnectionUriUtils - Class in org.apache.druid.utils
- constant(Double, int) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
- constant(Long, int) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
- constant(String) - Static method in interface org.apache.druid.segment.DimensionSelector
- constant(String, int) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
- constant(String, ExtractionFn) - Static method in interface org.apache.druid.segment.DimensionSelector
- CONSTANT - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression has no inputs and can be optimized into a constant selector
- CONSTANT - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- 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
- ConstantFrameRowPointer - Class in org.apache.druid.frame.segment.row
- ConstantFrameRowPointer(long, long) - Constructor for class org.apache.druid.frame.segment.row.ConstantFrameRowPointer
- ConstantMatcherType - Enum in org.apache.druid.segment.filter
- ConstantMultiValueDimensionSelector - Class in org.apache.druid.segment
- ConstantMultiValueDimensionSelector(List<String>) - Constructor for class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- ConstantObjectColumn - Class in org.apache.druid.query.rowsandcols.column
- ConstantObjectColumn(Object, int, ColumnType) - Constructor for class org.apache.druid.query.rowsandcols.column.ConstantObjectColumn
- ConstantPostAggregator - Class in org.apache.druid.query.aggregation.post
- ConstantPostAggregator(String, Number) - Constructor for class org.apache.druid.query.aggregation.post.ConstantPostAggregator
- constantValue - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
- ConstantVectorSelectors - Class in org.apache.druid.segment.vector
- ConstantVectorSelectors() - Constructor for class org.apache.druid.segment.vector.ConstantVectorSelectors
- contains(float[]) - Method in class org.apache.druid.collections.spatial.Node
- 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(int) - Method in class org.apache.druid.collections.RangeIntSet
- contains(int) - Method in class org.apache.druid.extendedset.intset.ConciseSet
- contains(int) - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- contains(int) - Method in class org.apache.druid.segment.column.RowSignature
- contains(Object) - Method in class org.apache.druid.collections.IntegerSet
- contains(Object) - Method in class org.apache.druid.math.expr.CartesianList
- contains(String) - Method in class org.apache.druid.segment.column.RowSignature
-
Returns whether this signature contains a named column.
- contains(TCoordinateArray) - Method in interface org.apache.druid.collections.spatial.search.Bound
- 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
- containsKey(String) - Method in class org.apache.druid.query.QueryContext
-
Check if the given key is set.
- containsRootPartition(T) - Method in interface org.apache.druid.timeline.Overshadowable
- ContainsSearchQuerySpec - Class in org.apache.druid.query.search
- ContainsSearchQuerySpec(String, boolean) - Constructor for class org.apache.druid.query.search.ContainsSearchQuerySpec
- containsValue(Object, TypeSignature<ValueType>) - Method in interface org.apache.druid.segment.index.semantic.ArrayElementIndexes
-
Get the
ImmutableBitmap
corresponding to rows with array elements matching the supplied value. - ContentEncoding - Enum in org.apache.druid.java.util.emitter.core
- context - Variable in exception org.apache.druid.error.DruidException
- context() - Method in class org.apache.druid.query.BaseQuery
- context() - Method in interface org.apache.druid.query.Query
-
Returns the query context as a
QueryContext
, which provides convenience methods for accessing typed context values. - 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(Map<String, Object>) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- context(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- context(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
- context(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
-
Sets
Query.getContext()
of the given query as dimension. - CONTEXT_KEY - Static variable in class org.apache.druid.concurrent.TaskThreadPriority
- conversions - Variable in class org.apache.druid.segment.DictionaryMergingIterator
- convert(int) - Method in interface org.apache.druid.timeline.partition.BucketNumberedShardSpec
- convert(int) - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- convert(int) - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- convert(int) - Method in class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- convert(int) - Method in interface org.apache.druid.timeline.partition.BuildingShardSpec
- convert(int) - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- convert(int) - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- convert(int) - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- convert(int) - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- convert(int...) - Method in class org.apache.druid.extendedset.intset.ConciseSet
- convertByteToConfig(byte[], Class<? extends T>, T) - Method in class org.apache.druid.common.config.JacksonConfigManager
- converterFromTypeToType(TypeSignature<ValueType>, TypeSignature<ValueType>) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
-
Used by TopN engine for type coercion
- convertJoinsToFilters(List<JoinableClause>, Set<String>, int) - Static method in class org.apache.druid.segment.join.JoinableFactoryWrapper
-
Converts any join clauses to filters that can be converted, and returns the rest as-is.
- convertJsonNode(JsonNode, CharsetEncoder) - Static method in class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- 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, TypeSignature<ValueType>) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- convertObjectToType(Object, TypeSignature<ValueType>, boolean) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- convertRowTypesToOutputTypes(List<DimensionSpec>, ResultRow, int) - Static method in class org.apache.druid.query.groupby.GroupingEngine
- convertSortedSegmentRowValuesToMergedRowValues(int, ColumnValueSelector) - Method in class org.apache.druid.segment.AutoTypeColumnMerger
- convertSortedSegmentRowValuesToMergedRowValues(int, ColumnValueSelector) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- 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.NestedDataColumnMergerV4
- convertSortedSegmentRowValuesToMergedRowValues(int, ColumnValueSelector) - Method in class org.apache.druid.segment.NumericDimensionMergerV9
- convertSpatialSchema(SpatialDimensionSchema) - Static method in class org.apache.druid.data.input.impl.DimensionsSpec
- convertToArray(Object, TypeSignature<ValueType>) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- 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
- convertToReadOnly() - Method in class org.apache.druid.frame.processor.OutputChannel
-
Removes the reference to the
OutputChannel.writableChannel
andOutputChannel.frameMemoryAllocator
from the object, making it more efficient - convertToReadOnly() - Method in class org.apache.druid.frame.processor.PartitionedOutputChannel
-
Removes the reference to the
PartitionedOutputChannel.writableChannel
andPartitionedOutputChannel.frameMemoryAllocator
from the object, making it more efficient - convertToSet(byte) - Static method in class org.apache.druid.segment.nested.FieldTypeInfo
- convertUnsortedEncodedKeyComponentToActualList(int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
- 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(StructuredData) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- convertUnsortedEncodedKeyComponentToActualList(StructuredData) - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- convertUnsortedValuesToSorted(ColumnValueSelector) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- convertUnsortedValuesToSorted(ColumnValueSelector) - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- 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.NestedDataColumnIndexerV4
- copy() - Method in class org.apache.druid.jackson.DefaultObjectMapper
- copy() - Method in class org.apache.druid.java.util.http.client.Request
- 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(DataSourceMetadataQuery) - Static method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
- copy(SegmentMetadataQuery) - Static method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- 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(TimeBoundaryQuery) - Static method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
- copy(TimeseriesQuery) - Static method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- copy(TopNQuery) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
-
Deprecated.
- copy(TopNQueryBuilder) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
-
Deprecated.
- COPY - org.apache.druid.java.util.common.FileUtils.LinkOrCopyResult
- copyAndClose(InputStream, OutputStream) - Static method in class org.apache.druid.java.util.common.StreamUtils
-
Copy from `is` to `os` and close the streams regardless of the result.
- copyBufferAndGet(ByteBuffer, int, int) - Method in class org.apache.druid.segment.data.GenericIndexed
- copyByteBufferToMemory(ByteBuffer, WritableMemory, long, int, boolean) - Static method in class org.apache.druid.frame.write.FrameWriterUtils
-
Copies "len" bytes from
src.position()
to "dstPosition" in "memory". - copyFrom(ExprParser.ExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExprContext
- copyFrom(ExprParser.FnArgsContext) - Method in class org.apache.druid.math.expr.antlr.ExprParser.FnArgsContext
- 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.
- copyInto(Object[], int) - Method in class org.apache.druid.query.rowsandcols.column.DefaultVectorCopier
- copyInto(Object[], int) - Method in interface org.apache.druid.query.rowsandcols.column.VectorCopier
-
Copies all values from the underlying column into the
Object[]
passed into this method. - copyKey(T) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerdeFactory
-
Copies a key.
- copyLarge(FileUtils.InputStreamSupplier, File, byte[], Predicate<Throwable>, int, String) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Copy a potentially large amount of data from an input source to a file.
- copyLarge(T, ObjectOpenFunction<T>, File, byte[], Predicate<Throwable>, int, String) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Copies data from the InputStream opened with objectOpenFunction to the given file.
- copyOf(Collection<String>) - Static method in class org.apache.druid.query.filter.InDimFilter.ValuesSet
-
Creates a ValuesSet copying the provided collection.
- copyOf(Iterator<String>) - Static method in class org.apache.druid.query.filter.InDimFilter.ValuesSet
-
Creates a ValuesSet copying the provided iterator, with
NullHandling.emptyToNullIfNeeded(String)
applied. - copyOf(ColumnCapabilities) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- copySign(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- CopySign() - Constructor for class org.apache.druid.math.expr.Function.CopySign
- copyTo(long, WritableMemory, long, long) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- copyTo(MemoryOpenHashTable, MemoryOpenHashTable.BucketCopyHandler) - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
-
Copy this table into another one.
- copyToFileAndClose(InputStream, File) - Static method in class org.apache.druid.java.util.common.StreamUtils
-
Copy from an input stream to a file (and buffer it) and close the input stream.
- copyWithOnlyVisibleChunks(PartitionHolder<T>) - Static method in class org.apache.druid.timeline.partition.PartitionHolder
- CORRECTION_PARAMETER - Static variable in class org.apache.druid.hll.HyperLogLogCollector
- cos(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Cos() - Constructor for class org.apache.druid.math.expr.Function.Cos
- cosh(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Cosh() - Constructor for class org.apache.druid.math.expr.Function.Cosh
- cot(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Cot() - Constructor for class org.apache.druid.math.expr.Function.Cot
- count - Variable in class org.apache.druid.query.aggregation.Histogram
- count(long) - Static method in class org.apache.druid.java.util.emitter.core.ConcurrentTimeCounter
- 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.AutoTypeColumnMerger.ArrayDictionaryMergingIterator
- counter - Variable in class org.apache.druid.segment.DictionaryMergingIterator
- counter - Variable in class org.apache.druid.segment.SimpleDictionaryMergingIterator
- countNumberOfFilters(Filter) - Static method in class org.apache.druid.segment.filter.Filters
- countRequiredMergeBufferNumForMergingQueryRunner(GroupByQueryConfig, GroupByQuery) - Static method in class org.apache.druid.query.groupby.GroupByQueryResources
-
Count the number of merge buffers required for
GroupByMergingQueryRunner
It can be either 1 or 2, depending on the query's config - countRequiredMergeBufferNumForToolchestMerge(GroupByQuery) - Static method in class org.apache.druid.query.groupby.GroupByQueryResources
-
Counts the number of merge buffers required for
GroupByQueryQueryToolChest.mergeResults(org.apache.druid.query.QueryRunner<org.apache.druid.query.groupby.ResultRow>)
. - 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
- Cpu - Class in org.apache.druid.java.util.metrics.cgroups
-
Collect CPU share and quota information from cpu cgroup files.
- Cpu(CgroupDiscoverer) - Constructor for class org.apache.druid.java.util.metrics.cgroups.Cpu
- CPU_CONSUMED_NANOS - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
The total CPU time for threads related to Sequence processing of the query.
- Cpu.CpuAllocationMetric - Class in org.apache.druid.java.util.metrics.cgroups
- CpuAcct - Class in org.apache.druid.java.util.metrics.cgroups
- CpuAcct(CgroupDiscoverer) - Constructor for class org.apache.druid.java.util.metrics.cgroups.CpuAcct
- CpuAcct.CpuAcctMetric - Class in org.apache.druid.java.util.metrics.cgroups
- CpuAcctDeltaMonitor - Class in org.apache.druid.java.util.metrics
- CpuAcctDeltaMonitor() - Constructor for class org.apache.druid.java.util.metrics.CpuAcctDeltaMonitor
- CpuAcctDeltaMonitor(String, Map<String, String[]>, CgroupDiscoverer) - Constructor for class org.apache.druid.java.util.metrics.CpuAcctDeltaMonitor
- CpuAcctDeltaMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.CpuAcctDeltaMonitor
- CpuAcctDeltaMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.CpuAcctDeltaMonitor
- cpuCount() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
- CpuSet - Class in org.apache.druid.java.util.metrics.cgroups
-
Collect CPU and memory data from cpuset cgroup files.
- CpuSet(CgroupDiscoverer) - Constructor for class org.apache.druid.java.util.metrics.cgroups.CpuSet
- CpuSet.CpuSetMetric - Class in org.apache.druid.java.util.metrics.cgroups
- CPUTimeMetricQueryRunner<T> - Class in org.apache.druid.query
- create() - Static method in class org.apache.druid.java.util.common.io.Closer
-
Creates a new
Closer
. - create() - Static method in class org.apache.druid.query.filter.InDimFilter.ValuesSet
-
Creates an empty ValuesSet.
- create() - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadBufferFactory
- create(boolean) - Method in class org.apache.druid.segment.IndexMergerV9Factory
- create(int) - Static method in class org.apache.druid.query.groupby.ResultRow
-
Create a row of a certain size, initialized to all nulls.
- create(int, String) - Method in interface org.apache.druid.java.util.common.concurrent.ScheduledExecutorFactory
- create(Iterable<T>) - Static method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- create(Iterable<T>, Comparator<T>, BinaryOperator<T>) - Static method in class org.apache.druid.collections.CombiningIterable
- create(Iterable<Type1>, Iterable<Type2>, Iterable<Type3>, TrinaryFn<Type1, Type2, Type3, RetType>) - Static method in class org.apache.druid.java.util.common.guava.nary.TrinaryTransformIterable
- create(Object) - Static method in class org.apache.druid.segment.nested.StructuredData
- create(String) - Static method in class org.apache.druid.data.input.impl.StringDimensionSchema
- create(String) - Static method in class org.apache.druid.query.TableDataSource
- create(String...) - Static method in class org.apache.druid.data.input.StringTuple
- create(String, boolean) - Static method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
-
Create a channel that aims to limit its memory footprint to one frame.
- create(String, int, int) - Static method in class org.apache.druid.indexer.TaskLocation
- create(String, int, int, boolean) - Static method in class org.apache.druid.indexer.TaskLocation
- create(String, int, int, boolean, String) - Static method in class org.apache.druid.indexer.TaskLocation
- create(String, int, ColumnType) - Static method in class org.apache.druid.frame.read.columnar.FrameColumnReaders
- create(String, Object...) - Static method in class org.apache.druid.java.util.emitter.service.AlertBuilder
- create(String, String, String, Map<String, String>) - Static method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- create(String, MetadataStorageActionHandlerTypes<EntryType, StatusType, LogType, LockType>) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandlerFactory
- create(String, ColumnType) - Static method in class org.apache.druid.frame.field.FieldReaders
-
Helper used by
FrameReader
. - create(String, SegmentWriteOutMedium, String, int, CompressionStrategy) - Static method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSerializer
- create(String, SegmentWriteOutMedium, String, int, CompressionStrategy, Closer) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSerializer
- create(String, SegmentWriteOutMedium, String, CompressionStrategy) - Static method in class org.apache.druid.segment.DoubleColumnSerializer
- 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.DoubleColumnSerializerV2
- create(String, SegmentWriteOutMedium, String, CompressionStrategy, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.FloatColumnSerializerV2
- 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(ByteBuffer) - Static method in class org.apache.druid.frame.allocation.ArenaMemoryAllocator
-
Creates an allocator based on a specific
ByteBuffer
. - create(ByteBuffer, ByteBufferProvider, CompressionStrategy.Decompressor) - Static method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadReader
- create(Iterator<T>) - Static method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- create(Iterator<T>, Comparator<T>, BinaryOperator<T>) - Static method in class org.apache.druid.collections.CombiningIterator
- create(Iterator<Type1>, Iterator<Type2>, Iterator<Type3>, TrinaryFn<Type1, Type2, Type3, RetType>) - Static method in class org.apache.druid.java.util.common.guava.nary.TrinaryTransformIterator
- create(List<?>) - Static method in class org.apache.druid.query.topn.TopNResultValue
- create(List<? extends List<? extends E>>) - Static method in class org.apache.druid.math.expr.CartesianList
- create(List<String>) - Method in class org.apache.druid.data.input.impl.LocalInputSourceFactory
- create(List<String>) - Method in interface org.apache.druid.data.input.InputSourceFactory
- create(List<KeyColumn>, RowSignature) - Static method in class org.apache.druid.frame.key.ByteRowKeyComparator
- create(List<KeyColumn>, RowSignature) - Static method in class org.apache.druid.frame.key.RowKeyComparator
- create(List<KeyColumn>, RowSignature) - Static method in class org.apache.druid.frame.key.RowKeyComparisonRunLengths
- create(List<VirtualColumn>) - Static method in class org.apache.druid.segment.VirtualColumns
- create(Properties, Binder, TypeLiteral<T>) - Static method in class org.apache.druid.guice.ConditionalMultibind
-
Create a ConditionalMultibind that resolves items to be added to the set at "binding" time.
- create(Properties, Binder, TypeLiteral<T>, Class<? extends Annotation>) - Static method in class org.apache.druid.guice.ConditionalMultibind
-
Create a ConditionalMultibind that resolves items to be added to the set at "binding" time.
- create(Properties, Binder, Class<T>) - Static method in class org.apache.druid.guice.ConditionalMultibind
-
Create a ConditionalMultibind that resolves items to be added to the set at "binding" time.
- create(Properties, Binder, Class<T>, Class<? extends Annotation>) - Static method in class org.apache.druid.guice.ConditionalMultibind
-
Create a ConditionalMultibind that resolves items to be added to the set at "binding" time.
- create(Properties, AsyncHttpClient, ObjectMapper, Lifecycle) - Static method in class org.apache.druid.java.util.emitter.core.Emitters
- create(Properties, AsyncHttpClient, Lifecycle) - Static method in class org.apache.druid.java.util.emitter.core.Emitters
- create(MemoryAllocator) - Static method in class org.apache.druid.frame.allocation.AppendableMemory
-
Creates an appendable memory instance with a default initial allocation size.
- create(MemoryAllocator, int) - Static method in class org.apache.druid.frame.allocation.AppendableMemory
-
Creates an appendable memory instance using a particular initial allocation size.
- create(Frame, RowSignature, List<KeyColumn>, List<FieldReader>) - Static method in class org.apache.druid.frame.key.FrameComparisonWidgetImpl
-
Create a
FrameComparisonWidget
for the given frame. - create(Granularity, boolean) - Static method in class org.apache.druid.query.ResultGranularTimestampComparator
- create(Sequence<T>, Comparator<T>, BinaryOperator<T>) - Static method in class org.apache.druid.common.guava.CombiningSequence
- create(Lifecycle, DruidProcessingConfig) - Static method in class org.apache.druid.query.PrioritizedExecutorService
- create(JSONPathSpec, ObjectFlatteners.FlattenerMaker<T>) - Static method in class org.apache.druid.java.util.common.parsers.ObjectFlatteners
- create(DataSource, DataSource, String, String, JoinType, DimFilter, ExprMacroTable, JoinableFactoryWrapper) - Static method in class org.apache.druid.query.JoinDataSource
-
Create a join dataSource from a string condition.
- create(DataSource, DataSource, String, JoinConditionAnalysis, JoinType, DimFilter, JoinableFactoryWrapper) - Static method in class org.apache.druid.query.JoinDataSource
-
Create a join dataSource from an existing
JoinConditionAnalysis
. - create(DataSource, DimFilter) - Static method in class org.apache.druid.query.FilteredDataSource
- create(DataSource, VirtualColumn, DimFilter) - Static method in class org.apache.druid.query.UnnestDataSource
- create(Grouper.KeySerde<T>, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.ReusableEntry
-
Create a new instance based on a particular
Grouper.KeySerde
and a particular Object values size. - create(LookupExtractor, ColumnSelectorFactory, JoinConditionAnalysis, boolean) - Static method in class org.apache.druid.segment.join.lookup.LookupJoinMatcher
- create(QueryRunner<K>, QueryToolChest<K, J>) - Static method in class org.apache.druid.query.FluentQueryRunner
- create(ColumnCapabilities, DimensionSelector) - Static method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy
- create(RowSignature) - Static method in class org.apache.druid.frame.key.RowKeyReader
-
Creates a new
RowKeyReader
. - create(RowSignature) - Static method in class org.apache.druid.frame.read.FrameReader
-
Create a reader for frames with a given
RowSignature
. - create(ColumnSelectorFactory, String, ColumnType) - Static method in class org.apache.druid.frame.field.FieldWriters
-
Helper used by
RowBasedFrameWriterFactory
. - 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(Indexed<T>) - Static method in class org.apache.druid.segment.data.IndexedIterable
- create(RowAdapter<RowType>, Supplier<RowType>, ColumnInspector, boolean, 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(StorageAdapter, VectorCursor, Granularity, Interval) - Static method in class org.apache.druid.query.vector.VectorCursorGranularizer
- create(VectorOffset, VectorValueMatcher) - Static method in class org.apache.druid.segment.vector.FilteredVectorOffset
- create(VectorSizeInspector) - Static method in class org.apache.druid.segment.vector.NilVectorSelector
- create(VirtualColumn...) - Static method in class org.apache.druid.segment.VirtualColumns
- 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(DataSegment, DateTime) - Static method in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- create(T) - Static method in class org.apache.druid.collections.StupidResourceHolder
- createArray() - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- createAuditTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- createBindings(ColumnSelectorFactory, ExpressionPlan) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
-
Create
Expr.ObjectBinding
given aColumnSelectorFactory
andExpressionPlan
which provides the set of identifiers which need a binding (list of required columns), and context of whether or not they are used as array or scalar inputs - createChoice(Binder, String, Key<T>, Key<? extends T>) - Static method in class org.apache.druid.guice.PolyBind
-
Sets up a "choice" for the injector to resolve at injection time.
- createChoiceWithDefault(Binder, String, Key<T>, Key<? extends T>, String) - Static method in class org.apache.druid.guice.PolyBind
-
Deprecated.use
PolyBind.createChoiceWithDefault(Binder, String, Key, String)
instead.defaultKey
argument is ignored. - createChoiceWithDefault(Binder, String, Key<T>, String) - Static method in class org.apache.druid.guice.PolyBind
-
Sets up a "choice" for the injector to resolve at injection time.
- createChunk(O) - Method in interface org.apache.druid.timeline.partition.BucketNumberedShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- createChunk(T) - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- createChunk(T) - Method in interface org.apache.druid.timeline.partition.ShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- createChunk(T) - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- createClauses(List<PreJoinableClause>, JoinableFactory) - Static method in class org.apache.druid.segment.join.filter.JoinableClauses
-
Builds a list of
JoinableClause
corresponding to a list ofPreJoinableClause
. - createClient(HttpClientConfig, Lifecycle) - Static method in class org.apache.druid.java.util.http.client.HttpClientInit
- createColumnHeader() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectBufferStore
- createColumnHeader() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleBufferStore
- createColumnHeader() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatBufferStore
- createColumnHeader() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongBufferStore
- createColumnHeader() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringBufferStore
- 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.
- createCompoundJvmMonitor(Map<String, String[]>) - Static method in class org.apache.druid.java.util.metrics.Monitors
-
Creates a JVM monitor, configured with the given dimensions, that gathers all currently available JVM-wide monitors.
- createCompoundJvmMonitor(Map<String, String[]>, String) - Static method in class org.apache.druid.java.util.metrics.Monitors
-
Creates a JVM monitor, configured with the given dimensions, that gathers all currently available JVM-wide monitors:
JvmMonitor
,JvmCpuMonitor
andJvmThreadsMonitor
(this list may change in any future release of this library, including a minor release). - createConfigTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- CREATED_TIME - Static variable in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- createDataSourceTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- createDefault() - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
-
Creates a
ColumnCapabilitiesImpl
where allColumnCapabilities.Capable
that default to unknown instead are coerced to true or false - createDeltaEncodedSerde(AbstractSerializablePairLongObjectColumnHeader<SerializablePairLongDouble>) - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleBufferStore
- createDeltaEncodedSerde(AbstractSerializablePairLongObjectColumnHeader<SerializablePairLongFloat>) - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatBufferStore
- createDeltaEncodedSerde(AbstractSerializablePairLongObjectColumnHeader<SerializablePairLongLong>) - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongBufferStore
- createDeltaEncodedSerde(AbstractSerializablePairLongObjectColumnHeader<SerializablePairLongString>) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringBufferStore
- createDeltaEncodedSerde(AbstractSerializablePairLongObjectColumnHeader<T>) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectBufferStore
- createDeserializer(String) - Static method in class org.apache.druid.segment.serde.ComplexColumnPartSerde
- createDeserializer(ByteOrder) - Static method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde
- createDeserializer(ByteOrder) - Static method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde
- createDeserializer(ByteOrder, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2
- createDeserializer(ByteOrder, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2
- createDeserializer(ColumnType, boolean, boolean, boolean, ByteOrder, BitmapSerdeFactory) - Static method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- createDeserializer(BitmapSerdeFactory, ByteOrder) - Static method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
- createDictionary() - Static method in class org.apache.druid.query.groupby.epinephelinae.DictionaryBuildingUtils
-
Creates a forward dictionary (dictionary ID -> value).
- createEmittable(ServiceEmitter, String, Object...) - Static method in class org.apache.druid.java.util.emitter.service.AlertBuilder
- 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
- createEntity(CloudObjectLocation) - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
-
Create the correct
InputEntity
for this input source given a split on aCloudObjectLocation
. - createFactory(Properties) - Static method in class org.apache.druid.java.util.common.config.Config
- createFactory(Lifecycle) - Static method in class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
- createFile() - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage
-
Create a new temporary file.
- createFromType(ColumnType) - Static method in class org.apache.druid.frame.field.ComplexFieldReader
- createGrouperAccumulatorPair(GroupByQuery, GroupByQuery, GroupByQueryConfig, DruidProcessingConfig, 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 anAccumulator
that accepts ResultRows and forwards them to the grouper. - createGrouperAccumulatorPair(GroupByQuery, GroupByQuery, GroupByQueryConfig, DruidProcessingConfig, Supplier<ByteBuffer>, LimitedTemporaryStorage, ObjectMapper, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.RowBasedGrouperHelper
-
Create a single-threaded grouper and accumulator.
- createJqField(String, String) - Static method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- createKey() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
-
Create a reusable key that can be passed to
Grouper.KeySerde.readFromByteBuffer(T, java.nio.ByteBuffer, int)
. - createLazyCollectionFromStream(Supplier<Stream<E>>, int) - Static method in class org.apache.druid.utils.CollectionUtils
-
Returns a lazy collection from a stream supplier and a size.
- createLegacyFactory() - Static method in class org.apache.druid.segment.data.BitmapSerde
- createMap() - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- createMergeFn(Query<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- createMergeFn(Query<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupingEngine
-
See
QueryToolChest.createMergeFn(Query)
for details, allowsGroupByQueryQueryToolChest
to delegate implementation to the strategy - createMergeFn(Query<SegmentAnalysis>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
- 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<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
-
Creates a merge function that is used to merge intermediate aggregates from historicals in broker.
- createNestedField(String, String) - Static method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- 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"
- createNullHandlingComparator(Comparator<T2>, boolean) - Static method in class org.apache.druid.collections.SerializablePair
- createNumericTimestampParser(String) - Static method in class org.apache.druid.java.util.common.parsers.TimestampParser
- createObjectTimestampParser(String) - Static method in class org.apache.druid.java.util.common.parsers.TimestampParser
- createOnHeap(int) - Static method in class org.apache.druid.frame.allocation.ArenaMemoryAllocator
-
Creates an allocator of a specific size using an on-heap
ByteBuffer
. - createOpenCsvParser() - Static method in class org.apache.druid.data.input.impl.CsvInputFormat
- createPendingSegmentsTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- createReader(InputRowSchema, InputEntity, File) - Method in class org.apache.druid.data.input.impl.CsvInputFormat
- createReader(InputRowSchema, InputEntity, File) - Method in class org.apache.druid.data.input.impl.DelimitedInputFormat
- createReader(InputRowSchema, InputEntity, File) - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- createReader(InputRowSchema, InputEntity, File) - Method in class org.apache.druid.data.input.impl.RegexInputFormat
- createReader(InputRowSchema, InputEntity, File) - Method in interface org.apache.druid.data.input.InputFormat
- createResultComparator(Query<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- createResultComparator(Query<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupingEngine
-
See
QueryToolChest.createResultComparator(Query)
, allowsGroupByQueryQueryToolChest
to delegate implementation to the strategy - createResultComparator(Query<SegmentAnalysis>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
- 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<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
-
Creates an ordering comparator that is used to order results.
- createResultRowBasedColumnSelectorFactory(GroupByQuery, Supplier<ResultRow>, RowSignature.Finalization) - 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". - createReverseDictionary(Hash.Strategy<T>) - Static method in class org.apache.druid.query.groupby.epinephelinae.DictionaryBuildingUtils
-
Create reverse dictionary (value -> dictionary ID) that relies on the given
Hash.Strategy
for hashing and comparing equality. - createRootField(String) - Static method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- createRowAdapter(InputRowSchema) - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- createRowAdapter(InputRowSchema) - Method in interface org.apache.druid.data.input.InputFormat
-
Returns an adapter that can read the rows from
InputFormat.createReader(InputRowSchema, InputEntity, File)
, given a particularInputRowSchema
. - createRowIngestionMeters() - Method in interface org.apache.druid.segment.incremental.RowIngestionMetersFactory
- createRulesTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- 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 class org.apache.druid.query.operator.WindowOperatorQueryQueryRunnerFactory
- 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
- createSegmentMapFunction(Query, AtomicLong) - Method in interface org.apache.druid.query.DataSource
-
Returns a segment function on to how to segment should be modified.
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.FilteredDataSource
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.InlineDataSource
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.JoinDataSource
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.LookupDataSource
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.QueryDataSource
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.TableDataSource
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.UnionDataSource
- createSegmentMapFunction(Query, AtomicLong) - Method in class org.apache.druid.query.UnnestDataSource
- createSegmentSchemasTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
-
SegmentSchema table is created only when CentralizedDatasourceSchema feature is enabled.
- createSegmentTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- createSerde() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnHeader
- createSerde() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleColumnHeader
- createSerde() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatColumnHeader
- createSerde() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongColumnHeader
- createSerde() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringColumnHeader
- createSimpleArrayColumnCapabilities(TypeSignature<ValueType>) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- createSimpleNumericColumnCapabilities(TypeSignature<ValueType>) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
-
Create a no frills, simple column with
ValueType
set and everything else false - createSimpleSingleValueStringColumnCapabilities() - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
-
Simple, single valued, non dictionary encoded string without bitmap index or anything fancy
- createSplatted(Iterable<? extends Iterable<T>>, Comparator<T>) - Static method in class org.apache.druid.collections.CombiningIterable
-
Creates a CombiningIterable around a MergeIterable such that equivalent elements are thrown away If there are multiple Iterables in parameter "in" with equivalent objects, there are no guarantees around which object will win.
- createSplits(InputFormat, SplitHintSpec) - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- createSplits(InputFormat, SplitHintSpec) - Method in class org.apache.druid.data.input.impl.CombiningInputSource
- createSplits(InputFormat, SplitHintSpec) - Method in class org.apache.druid.data.input.impl.HttpInputSource
- createSplits(InputFormat, SplitHintSpec) - Method in class org.apache.druid.data.input.impl.LocalInputSource
- createSplits(InputFormat, SplitHintSpec) - Method in interface org.apache.druid.data.input.impl.SplittableInputSource
-
Creates a
Stream
ofInputSplit
s. - createStarted() - Static method in class org.apache.druid.java.util.common.Stopwatch
- createStarted(Ticker) - Static method in class org.apache.druid.java.util.common.Stopwatch
- createSupervisorsTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- createTaskTables() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- createTempDir() - Static method in class org.apache.druid.java.util.common.FileUtils
-
Creates a temporary directory inside the configured temporary space (java.io.tmpdir).
- createTempDir(String) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Creates a temporary directory inside the configured temporary space (java.io.tmpdir).
- createTempDirInLocation(Path, String) - Static method in class org.apache.druid.java.util.common.FileUtils
- createTimestampParser(String) - Static method in class org.apache.druid.java.util.common.parsers.TimestampParser
- createTreeField(String, List<String>) - Static method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- createUnstarted() - Static method in class org.apache.druid.java.util.common.Stopwatch
- createUpgradeSegmentsTable() - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- createWithColumnSize(SegmentWriteOutMedium, String, ObjectStrategy, int) - Static method in class org.apache.druid.segment.serde.LargeColumnSupportedComplexColumnSerializer
- CredentialedHttpClient - Class in org.apache.druid.java.util.http.client
- CredentialedHttpClient(Credentials, HttpClient) - Constructor for class org.apache.druid.java.util.http.client.CredentialedHttpClient
- Credentials - Interface in org.apache.druid.java.util.http.client.auth
- CryptoService - Class in org.apache.druid.crypto
-
Utility class for symmetric key encryption (i.e.
- CryptoService(String, String, String, String, String, Integer, Integer, Integer) - Constructor for class org.apache.druid.crypto.CryptoService
- CSV - org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser.FlatTextFormat
- CsvInputFormat - Class in org.apache.druid.data.input.impl
- CsvInputFormat(List<String>, String, Boolean, Boolean, int) - Constructor for class org.apache.druid.data.input.impl.CsvInputFormat
- CSVParser - Class in org.apache.druid.java.util.common.parsers
- CSVParser(String, boolean, int) - Constructor for class org.apache.druid.java.util.common.parsers.CSVParser
- CSVParser(String, Iterable<String>, boolean, int) - Constructor for class org.apache.druid.java.util.common.parsers.CSVParser
- CSVParseSpec - Class in org.apache.druid.data.input.impl
- CSVParseSpec(TimestampSpec, DimensionsSpec, String, List<String>, boolean, int) - Constructor for class org.apache.druid.data.input.impl.CSVParseSpec
- CTX_EXECUTION_MODE - Static variable in class org.apache.druid.query.QueryContexts
- 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_BUFFER_GROUPER_MAX_SIZE - Static variable in class org.apache.druid.query.groupby.GroupByQueryConfig
- CTX_KEY_ENABLE_MULTI_VALUE_UNNESTING - 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.GroupingEngine
- 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.GroupingEngine
- 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_STRATEGY - Static variable in class org.apache.druid.query.search.SearchQueryConfig
- CTX_SQL_QUERY_ID - Static variable in class org.apache.druid.query.QueryContexts
- CTX_SQL_STRINGIFY_ARRAYS - Static variable in class org.apache.druid.query.QueryContexts
- CTX_TIMESTAMP_RESULT_FIELD - Static variable in class org.apache.druid.query.groupby.GroupByQuery
- CTX_TIMESTAMP_RESULT_FIELD - Static variable in class org.apache.druid.query.timeseries.TimeseriesQuery
- CTX_TIMESTAMP_RESULT_FIELD_GRANULARITY - Static variable in class org.apache.druid.query.groupby.GroupByQuery
- CTX_TIMESTAMP_RESULT_FIELD_INDEX - Static variable in class org.apache.druid.query.groupby.GroupByQuery
- cumulativeProbability(int) - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
- cumulativeSince(CpuAcct.CpuAcctMetric) - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
- CURRENT_VERSION_ID - Static variable in class org.apache.druid.segment.IndexIO
- currentMetadata() - Method in interface org.apache.druid.java.util.common.parsers.CloseableIteratorWithMetadata
- currentRow() - Method in class org.apache.druid.segment.RowWalker
- CurrentTimeMillisSupplier - Class in org.apache.druid.common.utils
- CurrentTimeMillisSupplier() - Constructor for class org.apache.druid.common.utils.CurrentTimeMillisSupplier
- cursor() - Method in class org.apache.druid.frame.allocation.AppendableMemory
-
Return a pointer to the current cursor location, which is where the next elements should be written.
- 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. - CursorFrameRowPointer - Class in org.apache.druid.frame.segment.row
-
Row pointer based on a
ReadableOffset
containing a row number. - CursorFrameRowPointer(Frame, ReadableOffset) - Constructor for class org.apache.druid.frame.segment.row.CursorFrameRowPointer
- CursorOnlyStrategy - Class in org.apache.druid.query.search
- CursorOnlyStrategy.CursorBasedExecutor - Class in org.apache.druid.query.search
- cursorPosition - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- cursorToFramesIterable(Cursor, FrameWriterFactory) - Static method in class org.apache.druid.frame.segment.FrameCursorUtils
- cursorToFramesSequence(Cursor, FrameWriterFactory) - Static method in class org.apache.druid.frame.segment.FrameCursorUtils
D
- DATA_OFFSET - Static variable in class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- DATA_OFFSET - Static variable in class org.apache.druid.frame.write.columnar.FloatFrameMaker
- DATA_OFFSET - Static variable in class org.apache.druid.frame.write.columnar.LongFrameMaker
- DATA_OFFSET - Static variable in class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
-
A byte required at the beginning for type code
- DATA_OFFSET - Static variable in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
- 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
- dataMap - Variable in class org.apache.druid.java.util.emitter.service.AlertBuilder
- DataSegment - Class in org.apache.druid.timeline
-
Metadata of Druid's data segment.
- DataSegment(String, Interval, String, Map<String, Object>, List<String>, List<String>, ShardSpec, Integer, long) - Constructor for class org.apache.druid.timeline.DataSegment
- DataSegment(String, Interval, String, Map<String, Object>, List<String>, List<String>, ShardSpec, CompactionState, Integer, long) - Constructor for class org.apache.druid.timeline.DataSegment
- DataSegment(String, Interval, String, Map<String, Object>, List<String>, List<String>, ShardSpec, CompactionState, Integer, long, DataSegment.PruneSpecsHolder) - Constructor for class org.apache.druid.timeline.DataSegment
- DataSegment(SegmentId, Map<String, Object>, List<String>, List<String>, ShardSpec, CompactionState, Integer, long) - Constructor for class org.apache.druid.timeline.DataSegment
- DataSegment.Builder - Class in org.apache.druid.timeline
- DataSegment.PruneSpecsHolder - Class in org.apache.druid.timeline
-
This class is needed for optional injection of pruneLoadSpec and pruneLastCompactionState, see github.com/google/guice/wiki/FrequentlyAskedQuestions#how-can-i-inject-optional-parameters-into-a-constructor
- DataSegmentArchiver - Interface in org.apache.druid.segment.loading
-
DataSegmentArchiver knows how to archive segments.
- dataSegmentArchiverBinder(Binder) - Static method in class org.apache.druid.guice.Binders
- DataSegmentKiller - Interface in org.apache.druid.segment.loading
-
DataSegmentKiller knows how to kill segments from the Druid system.
- dataSegmentKillerBinder(Binder) - Static method in class org.apache.druid.guice.Binders
- DataSegmentMover - Interface in org.apache.druid.segment.loading
-
DataSegmentMover knows how to move the segment location from one to another.
- dataSegmentMoverBinder(Binder) - Static method in class org.apache.druid.guice.Binders
- DataSegmentPusher - Interface in org.apache.druid.segment.loading
- dataSegmentPusherBinder(Binder) - Static method in class org.apache.druid.guice.Binders
- DataSegmentsWithSchemas - Class in org.apache.druid.segment
-
This immutable class encapsulates segments metadata and corresponding schema.
- DataSegmentsWithSchemas(int) - Constructor for class org.apache.druid.segment.DataSegmentsWithSchemas
- DataSegmentsWithSchemas(Set<DataSegment>, SegmentSchemaMapping) - Constructor for class org.apache.druid.segment.DataSegmentsWithSchemas
- DataSegmentWithMetadata - Class in org.apache.druid.segment
-
Immutable wrapper class for segment and schema.
- DataSegmentWithMetadata(DataSegment, SchemaPayloadPlus) - Constructor for class org.apache.druid.segment.DataSegmentWithMetadata
- dataSource(String) - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
- dataSource(String) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- dataSource(String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- dataSource(String) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- dataSource(String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
- dataSource(String) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- dataSource(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- dataSource(String) - Method in class org.apache.druid.timeline.DataSegment.Builder
- dataSource(DataSource) - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
- dataSource(DataSource) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- dataSource(DataSource) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- dataSource(DataSource) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- dataSource(DataSource) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
- dataSource(DataSource) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- dataSource(DataSource) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- dataSource(Query<?>) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- dataSource(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- dataSource(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
- dataSource(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
-
Sets
Query.getDataSource()
of the given query as dimension. - DataSource - Interface in org.apache.druid.query
-
Represents a source...
- DATASOURCE - Static variable in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- DATASOURCE - Static variable in class org.apache.druid.query.DruidMetrics
- 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.
- DataSourceAnalysis(DataSource, Query<?>, DimFilter, List<PreJoinableClause>) - Constructor for class org.apache.druid.query.planning.DataSourceAnalysis
- 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
- DateTimes - Class in org.apache.druid.java.util.common
- DateTimes.UtcFormatter - Class in org.apache.druid.java.util.common
-
Simple wrapper class to enforce UTC Chronology in formatter.
- DAY - org.apache.druid.java.util.common.granularity.GranularityType
- DAY - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- DAY - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- DDSKETCH_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- DDSKETCH_QUANTILE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- DDSKETCH_QUANTILES_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- debug(String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- debug(Throwable, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- debug(Marker, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- DEBUG - org.apache.druid.java.util.emitter.core.LoggingEmitter.Level
- debugSegments(Collection<DataSegment>, String) - Method in class org.apache.druid.java.util.common.logger.Logger
- debugToString() - Method in interface org.apache.druid.segment.data.IndexedInts
- DECADE - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- DECIMAL - org.apache.druid.java.util.common.HumanReadableBytes.UnitSystem
-
simplified SI format without 'B' indicator eg: K, M, G ...
- DECIMAL_BYTE - org.apache.druid.java.util.common.HumanReadableBytes.UnitSystem
-
also known as SI format eg: B, KB, MB ...
- decode(String) - Static method in class org.apache.druid.segment.incremental.SpatialDimensionRowTransformer
-
Decodes encodedCoordinate.
- decodeBase64(byte[]) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Decode an input byte array using the
Base64
encoding scheme and return a newly-allocated byte array - decodeBase64String(String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Decode an input string using the
Base64
encoding scheme and return a newly-allocated byte array - decomposeAnd(Expr) - Static method in class org.apache.druid.math.expr.Exprs
-
Decomposes any expr into a list of exprs that, if ANDed together, are equivalent to the input expr.
- 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.
- decomposeEquals(Expr, String) - Static method in class org.apache.druid.math.expr.Exprs
-
Decomposes an equality expr into an
Equality
. - decompress(InputStream, String) - Static method in class org.apache.druid.utils.CompressionUtils
-
Decompress an input stream from a file, based on the filename.
- 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
- decompress(ByteBuffer, int, ByteBuffer) - Method in class org.apache.druid.segment.data.CompressionStrategy.ZstdDecompressor
- decompress(Memory, long, long) - Static method in class org.apache.druid.frame.Frame
-
Decompresses the provided memory and returns a frame backed by that decompressed memory.
- 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(InputRowParser<T>) - Method in class org.apache.druid.segment.transform.TransformSpec
- decorate(InputSourceReader) - Method in class org.apache.druid.segment.transform.TransformSpec
- decorate(DimensionSelector) - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
- decorate(DimensionSelector) - Method in interface org.apache.druid.query.dimension.DimensionSpec
-
Decorate a
DimensionSelector
, allowing custom transformation of underlying behavior (e.g. - 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(MultiValueDimensionVectorSelector) - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
- decorate(MultiValueDimensionVectorSelector) - Method in interface org.apache.druid.query.dimension.DimensionSpec
- decorate(SingleValueDimensionVectorSelector) - Method in class org.apache.druid.query.dimension.DefaultDimensionSpec
- decorate(SingleValueDimensionVectorSelector) - Method in interface org.apache.druid.query.dimension.DimensionSpec
-
Vectorized analog of
DimensionSpec.decorate(DimensionSelector)
forSingleValueDimensionVectorSelector
, most likely produced withVectorColumnSelectorFactory.makeSingleValueDimensionSelector(DimensionSpec)
Decoration allows aDimensionSpec
to customize the behavior of the underlying selector, for example transforming or filtering values. - decorateCacheKeyBuilder(CacheKeyBuilder) - Method in interface org.apache.druid.math.expr.Expr
-
Decorates the
CacheKeyBuilder
for the default implementation ofExpr.getCacheKey()
. - 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'sQueryToolChest
. - decoratePostAggregators(List<PostAggregator>, Map<String, AggregatorFactory>) - Static method in class org.apache.druid.query.Queries
- decorator(InputEntity) - Method in class org.apache.druid.data.input.impl.systemfield.SystemFieldDecoratorFactory
-
Create a decorator for the given
InputEntity
. - 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 callReferenceCountingCloseableObject.decrement()
only once. - decrypt(byte[]) - Method in class org.apache.druid.crypto.CryptoService
- deepCopy(PartitionHolder<T>) - Static method in class org.apache.druid.timeline.partition.PartitionHolder
- DEFAULT - org.apache.druid.java.util.common.granularity.Granularity.Formatter
- DEFAULT - Static variable in class org.apache.druid.java.util.common.parsers.JSONPathSpec
- DEFAULT - Static variable in enum org.apache.druid.java.util.emitter.service.AlertEvent.Severity
- DEFAULT - Static variable in interface org.apache.druid.segment.column.ColumnConfig
- DEFAULT - Static variable in interface org.apache.druid.segment.column.StringEncodingStrategy
- DEFAULT - Static variable in class org.apache.druid.segment.IndexSpec
- DEFAULT - Static variable in class org.apache.druid.timeline.DataSegment.PruneSpecsHolder
- DEFAULT_ALLOWED_PROTOCOLS - Static variable in class org.apache.druid.data.input.impl.HttpInputSourceConfig
- DEFAULT_BATCH_QUEUE_SIZE_LIMIT - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- DEFAULT_BATCH_SIZE - Static variable in class org.apache.druid.query.scan.ScanQuery
- DEFAULT_BATCHING_STRATEGY - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- DEFAULT_BUCKET_SIZE - Static variable in class org.apache.druid.segment.data.FrontCodedIndexed
- DEFAULT_BY_SEGMENT - Static variable in class org.apache.druid.query.QueryContexts
- DEFAULT_COLUMN - Static variable in class org.apache.druid.data.input.impl.TimestampSpec
- DEFAULT_COMPACTION_MAX_TOTAL_ROWS - Static variable in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- DEFAULT_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
- DEFAULT_COMPRESSION_CODEC - Static variable in class org.apache.druid.java.util.http.client.HttpClientConfig
- DEFAULT_COMPRESSION_STRATEGY - Static variable in enum org.apache.druid.segment.data.CompressionStrategy
- DEFAULT_CONTENT_ENCODING - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- DEFAULT_DIMENSION_ORDER - Static variable in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- DEFAULT_ENABLE_DEBUG - Static variable in class org.apache.druid.query.QueryContexts
- 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_ENABLE_REWRITE_JOIN_TO_FILTER - Static variable in class org.apache.druid.query.QueryContexts
- DEFAULT_ENABLE_SQL_JOIN_LEFT_SCAN_DIRECT - Static variable in class org.apache.druid.query.QueryContexts
- DEFAULT_ENABLE_TIME_BOUNDARY_PLANNING - Static variable in class org.apache.druid.query.QueryContexts
- DEFAULT_FETCH_BUFFER_SIZE - Static variable in interface org.apache.druid.data.input.InputEntity
- DEFAULT_FLUSH_COUNTS - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- DEFAULT_FLUSH_MILLIS - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- DEFAULT_FLUSH_TIME_OUT - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
-
Do not time out in case flushTimeOut is not set
- DEFAULT_HTTP_TIMEOUT_ALLOWANCE_FACTOR - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- DEFAULT_IN_SUB_QUERY_THRESHOLD - Static variable in class org.apache.druid.query.QueryContexts
- DEFAULT_INITIAL_BUFFERS_FOR_INTERMEDIATE_POOL - Static variable in class org.apache.druid.query.DruidProcessingBufferConfig
- DEFAULT_LIST_DELIMITER - Static variable in class org.apache.druid.java.util.common.parsers.Parsers
- DEFAULT_LONG_ENCODING_STRATEGY - Static variable in class org.apache.druid.segment.data.CompressionFactory
- DEFAULT_MAX_BATCH_SIZE - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
-
ensure the event buffers don't use more than 10% of memory by default
- DEFAULT_MAX_NUM_FETCH_TRIES - Static variable in interface org.apache.druid.data.input.InputEntity
- DEFAULT_MAX_ROWS_PER_SEGMENT - Static variable in interface org.apache.druid.indexer.partitions.PartitionsSpec
- DEFAULT_MAX_SIZE_BYTES - Static variable in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- DEFAULT_MAX_STRING_SIZE - Static variable in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- DEFAULT_MAX_TOTAL_ROWS - Static variable in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
-
Default maxTotalRows for most task types except compaction task.
- DEFAULT_MAX_TRIES - Static variable in class org.apache.druid.java.util.common.RetryUtils
- DEFAULT_MAX_VALUE_SIZE - Static variable in class org.apache.druid.query.aggregation.SingleValueAggregatorFactory
- DEFAULT_METRICS_FEED - Static variable in class org.apache.druid.java.util.metrics.FeedDefiningMonitor
- DEFAULT_MIN_HTTP_TIMEOUT_MILLIS - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
-
The default value effective doesn't set the min timeout
- DEFAULT_MIN_TOPN_THRESHOLD - Static variable in class org.apache.druid.query.topn.TopNQueryConfig
- DEFAULT_OPTIMIZATION_LEVEL - Static variable in class org.apache.druid.js.JavaScriptConfig
- DEFAULT_ORDERING - Static variable in class org.apache.druid.query.search.SearchSortSpec
- DEFAULT_PARTITION_DIMENSIONS - Static variable in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- 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.DruidProcessingBufferConfig
- DEFAULT_SECONDARY_PARTITION_PRUNING - Static variable in class org.apache.druid.query.QueryContexts
- DEFAULT_SKIP_VALUE_RANGE_INDEX_SCALE - Static variable in interface org.apache.druid.segment.column.ColumnConfig
-
this value was chosen testing range filters on double columns with a variety of ranges at which this ratio of number of bitmaps compared to total number of rows appeared to be around the threshold where indexes stopped performing consistently faster than a full scan + value matcher
- DEFAULT_SPLIT_HINT_SPEC - Static variable in interface org.apache.druid.data.input.impl.SplittableInputSource
- DEFAULT_STRING_CAPABILITIES - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
- DEFAULT_TASK_INITIAL_YIELD_NUM_ROWS - Static variable in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence
- DEFAULT_TASK_SMALL_BATCH_NUM_ROWS - Static variable in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence
- DEFAULT_TASK_TARGET_RUN_TIME_MILLIS - Static variable in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence
- 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
- DEFAULT_VERSION - Static variable in class org.apache.druid.segment.data.FrontCodedIndexed
- DEFAULT_WINDOWING_STRICT_VALIDATION - 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
- DefaultBlockingPool<T> - Class in org.apache.druid.collections
-
Pool that pre-generates objects up to a limit, then permits possibly-blocking "take" operations.
- DefaultBlockingPool(Supplier<T>, int) - Constructor for class org.apache.druid.collections.DefaultBlockingPool
- DefaultClusteredGroupPartitioner - Class in org.apache.druid.query.rowsandcols.semantic
- DefaultClusteredGroupPartitioner(RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultClusteredGroupPartitioner
- DefaultColumnFormatConfig - Class in org.apache.druid.segment
- DefaultColumnFormatConfig(Integer) - Constructor for class org.apache.druid.segment.DefaultColumnFormatConfig
- DefaultColumnSelectorFactoryMaker - Class in org.apache.druid.query.rowsandcols.semantic
- DefaultColumnSelectorFactoryMaker(RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultColumnSelectorFactoryMaker
- DefaultColumnSelectorFactoryMaker.ColumnAccessorBasedColumnSelectorFactory - Class in org.apache.druid.query.rowsandcols.semantic
- DefaultDimensionSpec - Class in org.apache.druid.query.dimension
- DefaultDimensionSpec(String, String) - Constructor for class org.apache.druid.query.dimension.DefaultDimensionSpec
- DefaultDimensionSpec(String, String, ColumnType) - Constructor for class org.apache.druid.query.dimension.DefaultDimensionSpec
- defaultDoubleValue() - Static method in class org.apache.druid.common.config.NullHandling
- defaultFloatValue() - Static method in class org.apache.druid.common.config.NullHandling
- DefaultFramedOnHeapAggregatable - Class in org.apache.druid.query.rowsandcols.semantic
- DefaultFramedOnHeapAggregatable(AppendableRowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultFramedOnHeapAggregatable
- 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 aList<String>
, if the row has size > 1, usingDimensionDictionarySelector.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
- DefaultGroupPartitioner - Class in org.apache.druid.query.rowsandcols.semantic
- DefaultGroupPartitioner(RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultGroupPartitioner
- DefaultIndexIOHandler() - Constructor for class org.apache.druid.segment.IndexIO.DefaultIndexIOHandler
- DefaultLimitSpec - Class in org.apache.druid.query.groupby.orderby
- DefaultLimitSpec(List<OrderByColumnSpec>, Integer) - Constructor for class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
-
Constructor that does not accept "offset".
- DefaultLimitSpec(List<OrderByColumnSpec>, Integer, Integer) - Constructor for class org.apache.druid.query.groupby.orderby.DefaultLimitSpec
- DefaultLimitSpec.Builder - Class in org.apache.druid.query.groupby.orderby
- DefaultLimitSpec.LimitJsonIncludeFilter - Class in org.apache.druid.query.groupby.orderby
-
JsonInclude
filter forDefaultLimitSpec.getLimit()
. - defaultLongValue() - Static method in class org.apache.druid.common.config.NullHandling
- DefaultNaiveSortMaker - Class in org.apache.druid.query.rowsandcols.semantic
- DefaultNaiveSortMaker(RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultNaiveSortMaker
- DefaultObjectMapper - Class in org.apache.druid.jackson
- DefaultObjectMapper() - Constructor for class org.apache.druid.jackson.DefaultObjectMapper
- DefaultObjectMapper(JsonFactory, String) - Constructor for class org.apache.druid.jackson.DefaultObjectMapper
- DefaultObjectMapper(String) - Constructor for class org.apache.druid.jackson.DefaultObjectMapper
- DefaultObjectMapper(DefaultObjectMapper) - Constructor for class org.apache.druid.jackson.DefaultObjectMapper
- DefaultPasswordProvider - Class in org.apache.druid.metadata
- DefaultPasswordProvider(String) - Constructor for class org.apache.druid.metadata.DefaultPasswordProvider
- 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
- DefaultRowsAndColumnsDecorator - Class in org.apache.druid.query.rowsandcols.semantic
- DefaultRowsAndColumnsDecorator(RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- DefaultRowsAndColumnsDecorator(RowsAndColumns, Interval, Filter, VirtualColumns, OffsetLimit, List<ColumnWithDirection>) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- 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
- DefaultSortedMatrixMaker - Class in org.apache.druid.query.rowsandcols.semantic
-
The DefaultSortedMatrixMaker is a SortedMatrixMaker that works on the generic RowsAndColumns interface.
- DefaultSortedMatrixMaker(RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.semantic.DefaultSortedMatrixMaker
- defaultSpec() - Static method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- defaultStringValue() - Static method in class org.apache.druid.common.config.NullHandling
- 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
- DefaultTrueJsonIncludeFilter - Class in org.apache.druid.jackson
-
JsonInclude
filter for boolean values that default to true. - DefaultTrueJsonIncludeFilter() - Constructor for class org.apache.druid.jackson.DefaultTrueJsonIncludeFilter
- defaultType() - Method in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- 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.PredicateValueMatcherFactory
- defaultType() - Method in class org.apache.druid.segment.filter.StringConstantValueMatcherFactory
- defaultValueForClass(Class<T>) - Static method in class org.apache.druid.common.config.NullHandling
-
Returns the default value for an object of the provided class.
- defaultValueForType(ValueType) - Static method in class org.apache.druid.common.config.NullHandling
-
Returns the default value for the given
ValueType
. - DefaultVectorCopier - Class in org.apache.druid.query.rowsandcols.column
- DefaultVectorCopier(ColumnAccessor) - Constructor for class org.apache.druid.query.rowsandcols.column.DefaultVectorCopier
- defensive() - Static method in exception org.apache.druid.error.DruidException
-
Build a "defensive" exception, this is an exception that should never actually be triggered, but we are throwing it inside of a defensive check.
- defensive(String, Object...) - Static method in exception org.apache.druid.error.DruidException
-
Build a "defensive" exception, this is an exception that should never actually be triggered, but we are throwing it inside of a defensive check.
- DEFENSIVE - org.apache.druid.error.DruidException.Category
-
Means that the exception is being created defensively, because we want to validate something but expect that it should never actually be hit.
- defineClass(Class<?>, byte[], String) - Static method in class org.apache.druid.java.util.common.DefineClassUtils
- DefineClassUtils - Class in org.apache.druid.java.util.common
-
This utility class provides a thin runtime abstraction to pick between - sun.misc.Unsafe.defineClass in Java 8, - and MethodHandles.Lookup.defineClass in Java 9 and above, while still providing compile-time support for both Java 8 and Java 9+.
- DefineClassUtils() - Constructor for class org.apache.druid.java.util.common.DefineClassUtils
- DEFLATE - org.apache.druid.java.util.http.client.HttpClientConfig.CompressionCodec
- delegate - Variable in class org.apache.druid.math.expr.vector.CastToTypeVectorProcessor
- 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 - Variable in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
- delegate() - Method in class org.apache.druid.query.DirectQueryProcessingPool
- delegate() - Method in class org.apache.druid.query.filter.InDimFilter.ValuesSet
- delegate() - Method in class org.apache.druid.query.ForwardingQueryProcessingPool
- delegate() - Method in class org.apache.druid.query.lookup.ImmutableLookupMap
- delegate() - Method in class org.apache.druid.timeline.partition.PartitionBoundaries
- 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
- DelegatingYieldingAccumulator<OutType,T> - Class in org.apache.druid.java.util.common.guava
- DelegatingYieldingAccumulator(YieldingAccumulator<OutType, T>) - Constructor for class org.apache.druid.java.util.common.guava.DelegatingYieldingAccumulator
- delete(File) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage
- DELETE_ON_CLOSE - org.apache.druid.frame.file.FrameFile.Flag
-
Delete the opened frame file when all references are closed.
- deleteAllRecords(String) - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- deleteDirectory(File) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Equivalent to
FileUtils.deleteDirectory(File)
. - deleteFile(String) - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
-
Deletes the file present at the location basePath + path.
- deleteFile(String) - Method in class org.apache.druid.storage.NilStorageConnector
- deleteFile(String) - Method in interface org.apache.druid.storage.StorageConnector
-
Delete file present at the input path.
- deleteFiles(Iterable<String>) - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
-
Deletes the files present at each basePath + path.
- deleteFiles(Iterable<String>) - Method in class org.apache.druid.storage.NilStorageConnector
- deleteFiles(Iterable<String>) - Method in interface org.apache.druid.storage.StorageConnector
-
Delete files present at the input paths.
- deleteRecursively(String) - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
-
Deletes the files and sub dirs present at the basePath + dirName.
- deleteRecursively(String) - Method in class org.apache.druid.storage.NilStorageConnector
- deleteRecursively(String) - Method in interface org.apache.druid.storage.StorageConnector
-
Delete a directory pointed to by the path and also recursively deletes all files/directories in said directory.
- DELIMITED - org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser.FlatTextFormat
- DelimitedBytes - Class in org.apache.druid.data.input.impl
-
Utility function for
DelimitedInputFormat
. - DelimitedBytes() - Constructor for class org.apache.druid.data.input.impl.DelimitedBytes
- DelimitedInputFormat - Class in org.apache.druid.data.input.impl
-
InputFormat for customized Delimiter Separate Value format of input data (default is TSV).
- DelimitedInputFormat(List<String>, String, String, Boolean, Boolean, int) - Constructor for class org.apache.druid.data.input.impl.DelimitedInputFormat
- DelimitedParser - Class in org.apache.druid.java.util.common.parsers
- DelimitedParser(String, String, boolean, int) - Constructor for class org.apache.druid.java.util.common.parsers.DelimitedParser
- DelimitedParser(String, String, Iterable<String>, boolean, int) - Constructor for class org.apache.druid.java.util.common.parsers.DelimitedParser
- DelimitedParseSpec - Class in org.apache.druid.data.input.impl
- DelimitedParseSpec(TimestampSpec, DimensionsSpec, String, String, List<String>) - Constructor for class org.apache.druid.data.input.impl.DelimitedParseSpec
-
Deprecated.
- DelimitedParseSpec(TimestampSpec, DimensionsSpec, String, String, List<String>, boolean, int) - Constructor for class org.apache.druid.data.input.impl.DelimitedParseSpec
- DelimitedValueReader - Class in org.apache.druid.data.input.impl
-
DelimitedValueReader is the reader for Delimitor Separate Value format input data(CSV/TSV).
- DELTA - org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
-
DELTA format encodes a series of longs by finding the smallest value first, and stores all values as offset to the smallest value.
- 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
- DENSE_THRESHOLD - Static variable in class org.apache.druid.hll.HyperLogLogCollector
- DeprecatedQueryableIndexColumnSelector - Class in org.apache.druid.segment
-
Deprecated.
- DeprecatedQueryableIndexColumnSelector(QueryableIndex) - Constructor for class org.apache.druid.segment.DeprecatedQueryableIndexColumnSelector
-
Deprecated.
- 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
- DESC - org.apache.druid.query.operator.ColumnWithDirection.Direction
- descending(boolean) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- descending(String) - Static method in class org.apache.druid.query.operator.ColumnWithDirection
- descending(String...) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- DESCENDING - org.apache.druid.frame.key.KeyOrder
-
Ordered descending.
- DESCENDING - org.apache.druid.query.groupby.orderby.OrderByColumnSpec.Direction
- DESCENDING - org.apache.druid.query.scan.ScanQuery.Order
- descendingIterator() - Method in class org.apache.druid.extendedset.intset.AbstractIntSet
- descendingIterator() - Method in class org.apache.druid.extendedset.intset.ConciseSet
- descendingIterator() - Method in interface org.apache.druid.extendedset.intset.IntSet
- describe() - Method in class org.apache.druid.query.filter.FilterBundle.BundleInfo
-
Return a multiline description string, suitable for comparisons in tests.
- describe() - Method in class org.apache.druid.query.filter.FilterBundle.IndexBundleInfo
-
Return a multiline description string, suitable for comparisons in tests.
- describe() - Method in class org.apache.druid.query.filter.FilterBundle.MatcherBundleInfo
-
Return a multiline description string, suitable for comparisons in tests.
- description - Variable in class org.apache.druid.java.util.emitter.service.AlertBuilder
- descriptorPath(String) - Static method in interface org.apache.druid.segment.loading.DataSegmentKiller
- deserialize(byte[]) - Method in interface org.apache.druid.common.config.ConfigSerde
- deserialize(byte[]) - Method in interface org.apache.druid.segment.serde.cell.StagedSerde
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.druid.jackson.CommaListJoinDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.druid.query.context.ResponseContextDeserializer
- 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.ExpressionLambdaAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- deserialize(Object) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
- 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 givenObjectMapper
. - deserialize(ByteBuffer) - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleDeltaEncodedStagedSerde
- deserialize(ByteBuffer) - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleSimpleStagedSerde
- deserialize(ByteBuffer) - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatDeltaEncodedStagedSerde
- deserialize(ByteBuffer) - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatSimpleStagedSerde
- deserialize(ByteBuffer) - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongDeltaEncodedStagedSerde
- deserialize(ByteBuffer) - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongSimpleStagedSerde
- deserialize(ByteBuffer) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringDeltaEncodedStagedSerde
- deserialize(ByteBuffer) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringSimpleStagedSerde
- deserialize(ByteBuffer) - Method in interface org.apache.druid.segment.serde.cell.StagedSerde
- deserialize(ByteBuffer, int, int, ExpressionType, boolean) - Static method in class org.apache.druid.math.expr.ExprEval
-
Deserialize an expression stored in a bytebuffer, e.g.
- deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
- deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexMetricSerde
- deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexMetricSerde
- deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexMetricSerde
- deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexMetricSerde
- deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- deserializeColumn(ByteBuffer, ColumnBuilder) - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
-
Deprecated.
- deserializeColumn(ByteBuffer, ColumnBuilder, ColumnConfig) - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- deserializeColumn(ByteBuffer, ColumnBuilder, ColumnConfig) - 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 - org.apache.druid.indexer.IngestionState
- 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).
- detransformToDouble(long) - Static method in class org.apache.druid.frame.field.TransformUtils
-
Inverse of
TransformUtils.transformFromDouble(double)
. - detransformToFloat(int) - Static method in class org.apache.druid.frame.field.TransformUtils
-
Inverse of
TransformUtils.transformFromFloat(float)
. - detransformToLong(long) - Static method in class org.apache.druid.frame.field.TransformUtils
-
Reverse the
TransformUtils.transformFromLong(long)
function. - DEVELOPER - org.apache.druid.error.DruidException.Persona
-
Represents someone who has all of the context and knowledge to be actively diving into the Druid codebase.
- DICTIONARY_MERGING_COMPARATOR - Static variable in class org.apache.druid.segment.StringDimensionMergerV9
- DictionaryBuilding() - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.DictionaryBuilding
- DictionaryBuildingGroupByColumnSelectorStrategy<DimensionType> - Class in org.apache.druid.query.groupby.epinephelinae.column
-
Strategy for grouping dimensions which can have variable-width objects, and aren't backed by prebuilt dictionaries.
- DictionaryBuildingSingleValueStringGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
-
A
GroupByVectorColumnSelector
that builds an internal String<->Integer dictionary, used for grouping single-valued STRING columns which are not natively dictionary encoded, e.g. - DictionaryBuildingSingleValueStringGroupByVectorColumnSelector(VectorObjectSelector) - Constructor for class org.apache.druid.query.groupby.epinephelinae.vector.DictionaryBuildingSingleValueStringGroupByVectorColumnSelector
- DictionaryBuildingUtils - Class in org.apache.druid.query.groupby.epinephelinae
-
Utilities for parts of the groupBy engine that need to build dictionaries.
- DictionaryBuildingUtils() - Constructor for class org.apache.druid.query.groupby.epinephelinae.DictionaryBuildingUtils
- dictionaryEncoded() - Method in interface org.apache.druid.segment.column.ColumnCapabilities.CoercionLogic
-
If
ColumnCapabilities.isDictionaryEncoded()
isColumnCapabilities.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
- DictionaryEncodedColumnIndexer<KeyType,ActualType extends Comparable<ActualType>> - Class in org.apache.druid.segment
-
Basic structure for indexing dictionary encoded columns
- DictionaryEncodedColumnIndexer(DimensionDictionary<ActualType>) - Constructor for class org.apache.druid.segment.DictionaryEncodedColumnIndexer
-
Creates a new DictionaryEncodedColumnIndexer.
- DictionaryEncodedColumnMerger<T extends Comparable<T>> - Class in org.apache.druid.segment
-
Base structure for merging dictionary encoded columns
- DictionaryEncodedColumnMerger(String, IndexSpec, SegmentWriteOutMedium, ColumnCapabilities, ProgressIndicator, Closer) - Constructor for class org.apache.druid.segment.DictionaryEncodedColumnMerger
- DictionaryEncodedColumnMerger.ConvertingBitmapValues - Class in org.apache.druid.segment
- DictionaryEncodedColumnMerger.ExtendedIndexesMerger - Interface in org.apache.druid.segment
-
Specifies any additional per value indexes which should be constructed when
DictionaryEncodedColumnMerger.writeIndexes(List)
is called, on top of the standard bitmap index created withDictionaryEncodedColumnMerger.mergeBitmaps(java.util.List<java.nio.IntBuffer>, org.apache.druid.collections.bitmap.BitmapFactory, org.apache.druid.segment.DictionaryEncodedColumnMerger.IndexSeeker[], int)
- DictionaryEncodedColumnMerger.IndexSeeker - Interface in org.apache.druid.segment
- DictionaryEncodedColumnMerger.IndexSeekerWithConversion - Class in org.apache.druid.segment
-
Get old dictId from new dictId, and only support access in order
- DictionaryEncodedColumnMerger.IndexSeekerWithoutConversion - Class in org.apache.druid.segment
- DictionaryEncodedColumnPartSerde - Class in org.apache.druid.segment.serde
- DictionaryEncodedColumnPartSerde.Feature - Enum in org.apache.druid.segment.serde
- DictionaryEncodedColumnPartSerde.SerializerBuilder - Class in org.apache.druid.segment.serde
- DictionaryEncodedColumnPartSerde.VERSION - Enum in org.apache.druid.segment.serde
- DictionaryEncodedStringValueIndex - Interface in org.apache.druid.segment.index.semantic
-
This exposes a 'raw' view into bitmap value indexes of a string
DictionaryEncodedColumn
. - DictionaryEncodedValueIndex<T> - Interface in org.apache.druid.segment.index.semantic
-
This exposes a 'raw' view into bitmap value indexes for
DictionaryEncodedColumn
. - dictionaryEncodesAllValues() - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
-
returns true if all values are encoded in
DictionaryEncodedColumnIndexer.dimLookup
- dictionaryFull(int) - Static method in class org.apache.druid.query.groupby.epinephelinae.Groupers
- dictionaryIdLookup - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- DictionaryIdLookup - Class in org.apache.druid.segment.nested
-
Value to dictionary id lookup, backed with memory mapped dictionaries populated lazily by the supplied
- DictionaryIdLookup(String, Path, DictionaryWriter<String>, DictionaryWriter<Long>, DictionaryWriter<Double>, DictionaryWriter<int[]>) - Constructor for class org.apache.druid.segment.nested.DictionaryIdLookup
- dictionaryMergeIterator - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- DictionaryMergingIterator<T extends Comparable<T>> - Class in org.apache.druid.segment
-
Iterator for merging dictionaries for some comparable type into a single sorted dictionary, useful when merging dictionary encoded columns
- DictionaryMergingIterator(Indexed<T>[], Comparator<Pair<Integer, PeekingIterator<T>>>, boolean) - Constructor for class org.apache.druid.segment.DictionaryMergingIterator
- DictionaryRangeScanningBitmapIndex - Class in org.apache.druid.segment.index
-
Common
BitmapColumnIndex
implementation for indexes which need to scan a range of values. - DictionaryRangeScanningBitmapIndex(double, int) - Constructor for class org.apache.druid.segment.index.DictionaryRangeScanningBitmapIndex
- DictionaryScanningBitmapIndex - Class in org.apache.druid.segment.index
-
Common
BitmapColumnIndex
implementation for indexes which are computed by scanning the entire value dictionary of the underlying column to check if the value index matches the filter. - DictionaryScanningBitmapIndex(int) - Constructor for class org.apache.druid.segment.index.DictionaryScanningBitmapIndex
- DictionaryScanningBitmapIndex(int, double) - Constructor for class org.apache.druid.segment.index.DictionaryScanningBitmapIndex
- dictionarySerialized - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- dictionarySize - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- dictionaryValuesSorted() - Method in interface org.apache.druid.segment.column.ColumnCapabilities.CoercionLogic
-
If
ColumnCapabilities.areDictionaryValuesSorted()
()} isColumnCapabilities.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()
()} isColumnCapabilities.Capable.UNKNOWN
, define if it should be treated as true or false. - dictionaryWriter - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- dictionaryWriter - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- DictionaryWriter<T> - Interface in org.apache.druid.segment.data
- didSomething() - Method in class org.apache.druid.java.util.common.guava.FilteringYieldingAccumulator
- dimConversions - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- dimension - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
- 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 class org.apache.druid.query.topn.DefaultTopNQueryMetrics
- dimension(TopNQuery) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
-
Sets
TopNQuery.getDimensionSpec()
.getDimension()
of the given query as dimension. - DIMENSION_CAPABILITY_MERGE_LOGIC - Static variable in class org.apache.druid.segment.column.CapabilitiesBasedFormat
- DIMENSION_HANDLER_PROVIDERS - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
- 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
- DimensionBasedPartitionsSpec - Interface in org.apache.druid.indexer.partitions
-
PartitionsSpec based on dimension values.
- dimensionCardinality(int) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
- dimensionCardinality(int) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
- DimensionComparisonUtils - Class in org.apache.druid.query
-
Utility class to compare dimensions
- DimensionComparisonUtils() - Constructor for class org.apache.druid.query.DimensionComparisonUtils
- DimensionComparisonUtils.ArrayComparator<T> - Class in org.apache.druid.query
-
Creates a list comparator with custom comparator for the elements.
- DimensionComparisonUtils.ArrayComparatorForUnnaturalStringComparator - Class in org.apache.druid.query
-
Array comparator that converts the elements to their string representation, before comparing the values using the provided
StringComparator
. - DimensionDesc(int, String, DimensionHandler, boolean) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
- DimensionDictionary<T extends Comparable<T>> - Class in org.apache.druid.segment
-
Buildable dictionary for some comparable type.
- DimensionDictionary(Class<T>) - Constructor for class org.apache.druid.segment.DimensionDictionary
- DimensionDictionarySelector - Interface in org.apache.druid.segment
-
Interface containing dictionary-related methods common to
DimensionSelector
,SingleValueDimensionVectorSelector
, andMultiValueDimensionVectorSelector
. - 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).
- DimensionHandlerProvider<EncodedType extends Comparable<EncodedType>,EncodedKeyComponentType,ActualType extends Comparable<ActualType>> - Interface in org.apache.druid.segment
- DimensionHandlerUtils - Class in org.apache.druid.segment
- DimensionIdCodec<DimensionType> - Interface in org.apache.druid.query.groupby.epinephelinae.column
-
Dimension to integer id encoder - decoder i.e.
- 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.DictionaryEncodedColumnMerger
- 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
- DimensionRangeBucketShardSpec - Class in org.apache.druid.timeline.partition
-
See
BucketNumberedShardSpec
for how this class is used. - DimensionRangeBucketShardSpec(int, List<String>, StringTuple, StringTuple) - Constructor for class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- DimensionRangePartitionsSpec - Class in org.apache.druid.indexer.partitions
-
Spec to create partitions based on value ranges of multiple dimensions.
- DimensionRangePartitionsSpec(Integer, Integer, List<String>, boolean) - Constructor for class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- DimensionRangeShardSpec - Class in org.apache.druid.timeline.partition
-
ShardSpec
for partitioning based on ranges of one or more dimensions. - DimensionRangeShardSpec(List<String>, StringTuple, StringTuple, int, Integer) - Constructor for class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- dimensions - Variable in class org.apache.druid.timeline.partition.BaseDimensionRangeShardSpec
- dimensions(Iterable<String>) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- dimensions(String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- dimensions(List<String>) - Method in class org.apache.druid.timeline.DataSegment.Builder
- dimensions(List<DimensionSpec>) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- dimensions(DimensionSpec) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- DimensionSchema - Class in org.apache.druid.data.input.impl
- DimensionSchema(String, DimensionSchema.MultiValueHandling, boolean) - Constructor for class org.apache.druid.data.input.impl.DimensionSchema
- DimensionSchema.MultiValueHandling - Enum in org.apache.druid.data.input.impl
- 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.
- DimensionsSpec - Class in org.apache.druid.data.input.impl
- DimensionsSpec(List<DimensionSchema>) - Constructor for class org.apache.druid.data.input.impl.DimensionsSpec
- DimensionsSpec.Builder - Class in org.apache.druid.data.input.impl
- 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 customDimFilter#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
- dimLookup - Variable in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- 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, Object, ColumnType, 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.DictionaryMergingIterator
- directExecutor() - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- DirectExecutorService - Class in org.apache.druid.java.util.common.concurrent
-
Creates an executor service that runs each task in the thread that invokes
execute/submit
, as inThreadPoolExecutor.CallerRunsPolicy
This applies both to individually submitted tasks and to collections of tasks submitted viainvokeAll
orinvokeAny
. - DirectExecutorService() - Constructor for class org.apache.druid.java.util.common.concurrent.DirectExecutorService
- DirectQueryProcessingPool - Class in org.apache.druid.query
-
QueryProcessingPool
wrapper overExecs.directExecutor()
- discover(String) - Method in interface org.apache.druid.java.util.metrics.cgroups.CgroupDiscoverer
-
Returns a path for a specific cgroup.
- discover(String) - Method in class org.apache.druid.java.util.metrics.cgroups.ProcCgroupDiscoverer
-
Gets the path in the virtual FS for the given cgroup (cpu, mem, etc.).
- discover(String) - Method in class org.apache.druid.java.util.metrics.cgroups.ProcSelfCgroupDiscoverer
- discoverRootFields(JsonNode) - Method in class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- discoverRootFields(T) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
-
List all "root" fields.
- DISCRETE_UNIFORM - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- DISTINCT_COUNT_CACHE_KEY - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- div - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- Div() - Constructor for class org.apache.druid.math.expr.Function.Div
- DIV - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- DIV - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- divide(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- doAudit(AuditEntry) - Method in interface org.apache.druid.audit.AuditManager
- doAudit(AuditEntry, Handle) - Method in interface org.apache.druid.audit.AuditManager
-
Inserts an audit entry in audit table using the provided JDBI handle.
- doCall() - Method in class org.apache.druid.common.guava.ThreadRenamingCallable
- doComplement(ImmutableConciseSet) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- 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
- doIntersection(Iterator<ImmutableConciseSet>) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.AbstractMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.CgroupCpuMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.CgroupCpuSetMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.CgroupMemoryMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.CpuAcctDeltaMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.HttpPostEmitterMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.JvmCpuMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.JvmMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.JvmThreadsMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.NoopOshiSysMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.NoopSysMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.ParametrizedUriEmitterMonitor
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.SysMonitor
-
Deprecated.
- doMonitor(ServiceEmitter) - Method in class org.apache.druid.query.ExecutorServiceMonitor
- done() - Method in class org.apache.druid.java.util.http.client.io.AppendableByteArrayInputStream
- done() - Method in class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHolder
- done(ClientResponse<IntermediateType>) - Method in interface org.apache.druid.java.util.http.client.response.HttpResponseHandler
-
Called after the final handleResponse() or handleChunk() call, signifying that no more data will arrive.
- done(ClientResponse<InputStream>) - Method in class org.apache.druid.java.util.http.client.response.SequenceInputStreamResponseHandler
- done(ClientResponse<FrameFilePartialFetch>) - Method in class org.apache.druid.frame.file.FrameFileHttpResponseHandler
- done(ClientResponse<Either<StringFullResponseHolder, IntermediateType>>) - Method in class org.apache.druid.java.util.http.client.response.ObjectOrErrorResponseHandler
- done(ClientResponse<AppendableByteArrayInputStream>) - Method in class org.apache.druid.java.util.http.client.response.InputStreamResponseHandler
- done(ClientResponse<BytesFullResponseHolder>) - Method in class org.apache.druid.java.util.http.client.response.BytesFullResponseHandler
- done(ClientResponse<InputStreamFullResponseHolder>) - Method in class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHandler
- done(ClientResponse<StatusResponseHolder>) - Method in class org.apache.druid.java.util.http.client.response.StatusResponseHandler
- done(ClientResponse<StringFullResponseHolder>) - Method in class org.apache.druid.java.util.http.client.response.StringFullResponseHandler
- done(T, AutoCloseable) - Static method in class org.apache.druid.java.util.common.guava.Yielders
- doneWriting() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
-
Call method when caller is done adding chunks.
- doRun() - Method in class org.apache.druid.common.guava.ThreadRenamingRunnable
- 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 - org.apache.druid.math.expr.ExprType
- DOUBLE - org.apache.druid.segment.column.ValueType
-
64-bit double precision floating point number primitive type.
- DOUBLE - org.apache.druid.segment.MetricHolder.MetricType
- DOUBLE - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- DOUBLE - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- DOUBLE - Static variable in class org.apache.druid.math.expr.ExpressionType
- DOUBLE - Static variable in class org.apache.druid.segment.column.ColumnType
-
Druid 64-bit double precision floating point number primitive type.
- DOUBLE - Static variable in class org.apache.druid.segment.column.TypeStrategies
- DOUBLE() - Method in class org.apache.druid.math.expr.antlr.ExprParser.DoubleExprContext
- DOUBLE() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LiteralElementContext
- DOUBLE() - Method in class org.apache.druid.math.expr.antlr.ExprParser.NumericElementContext
- DOUBLE_ANY_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- DOUBLE_ARRAY - Static variable in class org.apache.druid.math.expr.ExpressionType
- DOUBLE_ARRAY - Static variable in class org.apache.druid.segment.column.ColumnType
-
An array of Doubles.
- DOUBLE_COMPARATOR - Static variable in class org.apache.druid.segment.DoubleDimensionIndexer
- DOUBLE_DICTIONARY_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- DOUBLE_DICTIONARY_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- 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_MERGING_COMPARATOR - Static variable in class org.apache.druid.segment.AutoTypeColumnMerger
- DOUBLE_MERGING_COMPARATOR - Static variable in class org.apache.druid.segment.NestedDataColumnMergerV4
- 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
- DOUBLE_TYPE_NAME - Static variable in class org.apache.druid.data.input.impl.DimensionSchema
- DOUBLE_VALUE_COLUMN_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- 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
- DoubleArrayColumn - Class in org.apache.druid.query.rowsandcols.column
- DoubleArrayColumn(double[]) - Constructor for class org.apache.druid.query.rowsandcols.column.DoubleArrayColumn
- DoubleArrayContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.DoubleArrayContext
- DoubleArrayFieldReader - Class in org.apache.druid.frame.field
-
Reader for fields written by
NumericArrayFieldWriter.getDoubleArrayFieldWriter(org.apache.druid.segment.ColumnValueSelector)
- DoubleArrayFieldReader() - Constructor for class org.apache.druid.frame.field.DoubleArrayFieldReader
- DoubleArrayFrameColumnReader - Class in org.apache.druid.frame.read.columnar
-
Reader for columns written by
DoubleArrayFrameColumnWriter
- DoubleArrayFrameColumnReader(int) - Constructor for class org.apache.druid.frame.read.columnar.DoubleArrayFrameColumnReader
- DoubleArrayFrameColumnWriter - Class in org.apache.druid.frame.write.columnar
-
Columnar frame writer for
ColumnType.DOUBLE_ARRAY
columns - DoubleArrayFrameColumnWriter(ColumnValueSelector, MemoryAllocator) - Constructor for class org.apache.druid.frame.write.columnar.DoubleArrayFrameColumnWriter
- DoubleBivariateMathFunction() - Constructor for class org.apache.druid.math.expr.Function.DoubleBivariateMathFunction
- 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
- DoubleCardinalityVectorProcessor - Class in org.apache.druid.query.aggregation.cardinality.vector
- DoubleCardinalityVectorProcessor(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.cardinality.vector.DoubleCardinalityVectorProcessor
- DoubleColumnAccessorBase - Class in org.apache.druid.query.rowsandcols.column.accessor
- DoubleColumnAccessorBase() - Constructor for class org.apache.druid.query.rowsandcols.column.accessor.DoubleColumnAccessorBase
- DoubleColumnSelector - Interface in org.apache.druid.segment
-
This interface is convenient for implementation of "double-sourcing"
ColumnValueSelector
s, it provides default implementations for allColumnValueSelector
's methods exceptBaseDoubleColumnValueSelector.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
- DoubleDimensionSchema - Class in org.apache.druid.data.input.impl
- DoubleDimensionSchema(String) - Constructor for class org.apache.druid.data.input.impl.DoubleDimensionSchema
- DoubleExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.DoubleExprContext
- DoubleFieldReader - Class in org.apache.druid.frame.field
-
Reads the values produced by
DoubleFieldWriter
- DoubleFieldWriter - Class in org.apache.druid.frame.field
-
Wraps a
BaseDoubleColumnValueSelector
and writes field values. - DoubleFirstAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- DoubleFirstAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregator
- DoubleFirstAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.first
- DoubleFirstAggregatorFactory(String, String, String) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- DoubleFirstBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- DoubleFirstBufferAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstBufferAggregator
- DoubleFirstLastVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast
-
Vectorized version of on heap aggregator for column selectors with type DOUBLE.
- DoubleFirstLastVectorAggregator(VectorValueSelector, VectorObjectSelector, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.DoubleFirstLastVectorAggregator
- DoubleFirstLastVectorAggregator(VectorValueSelector, VectorValueSelector, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.DoubleFirstLastVectorAggregator
- DoubleFirstVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- DoubleFirstVectorAggregator(VectorValueSelector, VectorObjectSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstVectorAggregator
- DoubleFirstVectorAggregator(VectorValueSelector, VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstVectorAggregator
- DoubleFrameColumnReader - Class in org.apache.druid.frame.read.columnar
- DoubleFrameColumnWriter - Class in org.apache.druid.frame.write.columnar
- DoubleFrameMaker - Class in org.apache.druid.frame.write.columnar
- DoubleFrameMaker(MemoryAllocator, boolean) - Constructor for class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- DoubleGreatestPostAggregator - Class in org.apache.druid.query.aggregation.post
- DoubleGreatestPostAggregator(String, List<PostAggregator>) - Constructor for class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
- DoubleGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
- DoubleLastAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- DoubleLastAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregator
- DoubleLastAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.last
- DoubleLastAggregatorFactory(String, String, String) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- DoubleLastBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- DoubleLastBufferAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.DoubleLastBufferAggregator
- DoubleLastVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- DoubleLastVectorAggregator(VectorValueSelector, VectorObjectSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.DoubleLastVectorAggregator
- DoubleLastVectorAggregator(VectorValueSelector, VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.DoubleLastVectorAggregator
- 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) - Constructor for class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
- DoubleMaxAggregatorFactory(String, String, String, ExprMacroTable) - 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) - Constructor for class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
- DoubleMinAggregatorFactory(String, String, String, ExprMacroTable) - 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.NilVectorAggregator
- 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
- DoubleOutDoubleInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
UnivariateDoubleFunctionVectorValueProcessor
for processing (double[]) -> double[] - DoubleOutDoubleInFunctionVectorValueProcessor(ExprVectorProcessor<double[]>, int) - Constructor for class org.apache.druid.math.expr.vector.DoubleOutDoubleInFunctionVectorValueProcessor
- DoubleOutDoubleLongInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
BivariateDoubleFunctionVectorValueProcessor
for processing (double[], long[]) -> double[] - DoubleOutDoubleLongInFunctionVectorValueProcessor(ExprVectorProcessor<double[]>, ExprVectorProcessor<long[]>, int) - Constructor for class org.apache.druid.math.expr.vector.DoubleOutDoubleLongInFunctionVectorValueProcessor
- DoubleOutDoublesInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
BivariateDoubleFunctionVectorValueProcessor
for processing (double[], double[]) -> double[] - DoubleOutDoublesInFunctionVectorValueProcessor(ExprVectorProcessor<double[]>, ExprVectorProcessor<double[]>, int) - Constructor for class org.apache.druid.math.expr.vector.DoubleOutDoublesInFunctionVectorValueProcessor
- DoubleOutLongDoubleInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
BivariateDoubleFunctionVectorValueProcessor
for processing (long[], double[]) -> double[] - DoubleOutLongDoubleInFunctionVectorValueProcessor(ExprVectorProcessor<long[]>, ExprVectorProcessor<double[]>, int) - Constructor for class org.apache.druid.math.expr.vector.DoubleOutLongDoubleInFunctionVectorValueProcessor
- DoubleOutLongInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
UnivariateDoubleFunctionVectorValueProcessor
for processing (long[]) -> double[] - DoubleOutLongInFunctionVectorValueProcessor(ExprVectorProcessor<long[]>, int) - Constructor for class org.apache.druid.math.expr.vector.DoubleOutLongInFunctionVectorValueProcessor
- DoubleOutLongsInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
BivariateDoubleFunctionVectorValueProcessor
for processing (long[], long[]) -> double[] - DoubleOutLongsInFunctionVectorValueProcessor(ExprVectorProcessor<long[]>, ExprVectorProcessor<long[]>, int) - Constructor for class org.apache.druid.math.expr.vector.DoubleOutLongsInFunctionVectorValueProcessor
- doublePower(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- 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) - Constructor for class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
- DoubleSumAggregatorFactory(String, String, String, ExprMacroTable) - 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, Object>) - Constructor for class org.apache.druid.query.topn.types.DoubleTopNColumnAggregatesProcessor
- DoubleTypeStrategy() - Constructor for class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- DoubleUnivariateMathFunction() - Constructor for class org.apache.druid.math.expr.Function.DoubleUnivariateMathFunction
- 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
- DOW - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- DOY - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- drain() - Method in class org.apache.druid.collections.StableLimitingSorter
-
Drain elements in sorted order (least first).
- drain(Collection<? super MemoryBoundLinkedBlockingQueue.ObjectContainer<T>>, int, long, TimeUnit) - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
-
Drain up to specified bytes worth of items from the queue into the provided buffer.
- drop(int) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- drop(int) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- DroppingIterable<T> - Class in org.apache.druid.java.util.common.guava
- DroppingIterable(Iterable<T>, int) - Constructor for class org.apache.druid.java.util.common.guava.DroppingIterable
- DroppingIterator<T> - Class in org.apache.druid.java.util.common.guava
- DroppingIterator(Iterator<T>, int) - Constructor for class org.apache.druid.java.util.common.guava.DroppingIterator
- 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 anExtensionPoint
of Druid. - DruidException - Exception in org.apache.druid.error
-
Represents an error condition exposed to the user and/or operator of Druid.
- DruidException.Category - Enum in org.apache.druid.error
-
Category of error.
- DruidException.DruidExceptionBuilder - Class in org.apache.druid.error
- DruidException.Failure - Class in org.apache.druid.error
- DruidException.PartialDruidExceptionBuilder - Class in org.apache.druid.error
- DruidException.Persona - Enum in org.apache.druid.error
-
The persona that the message on a DruidException is targeting
- DruidFloatPredicate - Interface in org.apache.druid.query.filter
-
Note: this is not a
PublicApi
or anExtensionPoint
of Druid. - DruidGuiceExtensions - Class in org.apache.druid.guice
- DruidGuiceExtensions() - Constructor for class org.apache.druid.guice.DruidGuiceExtensions
- DruidIntList - Class in org.apache.druid.collections.fastutil
- DruidIntList(int) - Constructor for class org.apache.druid.collections.fastutil.DruidIntList
- DruidLongPredicate - Interface in org.apache.druid.query.filter
-
Note: this is not a
PublicApi
or anExtensionPoint
of Druid. - DruidMetrics - Class in org.apache.druid.query
- DruidMetrics() - Constructor for class org.apache.druid.query.DruidMetrics
- DruidModule - Interface in org.apache.druid.initialization
-
A Guice module which also provides Jackson modules.
- DruidMonitorSchedulerConfig - Class in org.apache.druid.java.util.metrics
- DruidMonitorSchedulerConfig() - Constructor for class org.apache.druid.java.util.metrics.DruidMonitorSchedulerConfig
- DruidObjectPredicate<T> - Interface in org.apache.druid.query.filter
- DruidPredicateFactory - Interface in org.apache.druid.query.filter
- DruidPredicateIndexes - Interface in org.apache.druid.segment.index.semantic
-
Uses a
DruidPredicateFactory
to construct aBitmapColumnIndex
containing rows for all values which satisfy the predicate. - DruidPredicateMatch - Enum in org.apache.druid.query.filter
-
Three-value logic result for matching values with predicates produced by
DruidPredicateFactory
- DruidProcessingBufferConfig - Class in org.apache.druid.query
- DruidProcessingBufferConfig() - Constructor for class org.apache.druid.query.DruidProcessingBufferConfig
- DruidProcessingBufferConfig(HumanReadableBytes, Integer, Integer) - Constructor for class org.apache.druid.query.DruidProcessingBufferConfig
- DruidProcessingConfig - Class in org.apache.druid.query
- DruidProcessingConfig() - Constructor for class org.apache.druid.query.DruidProcessingConfig
- DruidProcessingConfig(String, Integer, Integer, Boolean, String, DruidProcessingBufferConfig, DruidProcessingIndexesConfig) - Constructor for class org.apache.druid.query.DruidProcessingConfig
- DruidProcessingIndexesConfig - Class in org.apache.druid.query
- DruidProcessingIndexesConfig() - Constructor for class org.apache.druid.query.DruidProcessingIndexesConfig
- DruidProcessingIndexesConfig(Double) - Constructor for class org.apache.druid.query.DruidProcessingIndexesConfig
- 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.
- DruidScopes - Class in org.apache.druid.guice
- DruidScopes() - Constructor for class org.apache.druid.guice.DruidScopes
- DruidSecondaryModule - Class in org.apache.druid.guice
- DruidSecondaryModule(Properties, ConfigurationObjectFactory, ObjectMapper, ObjectMapper, ObjectMapper, Validator) - Constructor for class org.apache.druid.guice.DruidSecondaryModule
- DSuppliers - Class in org.apache.druid.common.guava
- DSuppliers() - Constructor for class org.apache.druid.common.guava.DSuppliers
- dummy() - Static method in class org.apache.druid.java.util.common.concurrent.Execs
-
Returns an ExecutorService which is terminated and shutdown from the beginning and not able to accept any tasks.
- dummy(String) - Static method in class org.apache.druid.timeline.SegmentId
-
Creates a dummy SegmentId with the given data source.
- dummy(String, int) - Static method in class org.apache.druid.timeline.SegmentId
-
Creates a dummy SegmentId with the given data source and partition number.
- DummyBlockingPool<T> - Class in org.apache.druid.collections
-
BlockingPool with 0 maxSize, all take*() methods immediately throw
UnsupportedOperationException
. - DummyNonBlockingPool<T> - Class in org.apache.druid.collections
-
NonBlockingPool which is not able to allocate objects,
DummyNonBlockingPool.take()
throwsUnsupportedOperationException
. - duplicate() - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
-
Duplicates this reader, creating a new reader that does not share any state.
- 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.SafeWritableBuffer
- duplicate() - Method in class org.apache.druid.segment.data.TableLongEncodingReader
- duplicate(ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- DurableStoragePartitionedReadableFrameChannel - Class in org.apache.druid.frame.channel
- DurableStoragePartitionedReadableFrameChannel(StorageConnector, Supplier<FrameFileFooter>, String, ExecutorService, File) - Constructor for class org.apache.druid.frame.channel.DurableStoragePartitionedReadableFrameChannel
- DurableStorageUtils - Class in org.apache.druid.frame.util
-
Helper class that fetches the directory and file names corresponding to file location
- DurableStorageUtils() - Constructor for class org.apache.druid.frame.util.DurableStorageUtils
- duration(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- 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. - DurationCoercible - Class in org.apache.druid.java.util.common.config
- DurationCoercible() - Constructor for class org.apache.druid.java.util.common.config.DurationCoercible
- DurationGranularity - Class in org.apache.druid.java.util.common.granularity
-
DurationGranularity buckets data based on the length of a duration
- DurationGranularity(long, long) - Constructor for class org.apache.druid.java.util.common.granularity.DurationGranularity
- DurationGranularity(long, DateTime) - Constructor for class org.apache.druid.java.util.common.granularity.DurationGranularity
- DynamicConfigProvider<T> - Interface in org.apache.druid.metadata
-
This is used to get [secure] configuration in various places in an extensible way.
- DynamicConfigProviderUtils - Class in org.apache.druid.utils
- DynamicConfigProviderUtils() - Constructor for class org.apache.druid.utils.DynamicConfigProviderUtils
- DynamicPartitionsSpec - Class in org.apache.druid.indexer.partitions
-
Dynamically determine partitions in the middle of indexing.
- DynamicPartitionsSpec(Integer, Long) - Constructor for class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
E
- each(Sequence<T>) - Static method in class org.apache.druid.java.util.common.guava.Yielders
- earlierOf(DateTime, DateTime) - Static method in class org.apache.druid.java.util.common.DateTimes
-
Returns the earlier of the two given dates.
- EARLIEST - org.apache.druid.query.metadata.metadata.AggregatorMergeStrategy
- EIGHT_HOUR - org.apache.druid.java.util.common.granularity.GranularityType
- EIGHT_HOUR - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- either(TypeSignature<T>, TypeSignature<T>, T) - Static method in class org.apache.druid.segment.column.Types
-
Returns true if either supplied
TypeSignature.getType()
is the givenTypeDescriptor
Useful for choosing a commonTypeDescriptor
between twoTypeSignature
when one of the signatures might be null. - Either<L,R> - Class in org.apache.druid.java.util.common
-
Encapsulates either an "error" or a "value".
- elementType - Variable in class org.apache.druid.segment.column.BaseTypeSignature
- elementType() - Method in class org.apache.druid.math.expr.ExprEval
- elementType(ExpressionType) - Static method in class org.apache.druid.math.expr.ExpressionType
-
If an
ExpressionType
is an array, returnBaseTypeSignature.getElementType()
, otherwise the type is returned unchanged. - emit() - Method in class org.apache.druid.java.util.emitter.EmittingLogger.EmittingAlertBuilder
- emit() - Method in class org.apache.druid.java.util.emitter.service.AlertBuilder
- emit(Event) - Method in class org.apache.druid.java.util.emitter.core.ComposingEmitter
- emit(Event) - Method in interface org.apache.druid.java.util.emitter.core.Emitter
-
Emit an event.
- emit(Event) - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- emit(Event) - Method in class org.apache.druid.java.util.emitter.core.LoggingEmitter
- emit(Event) - Method in class org.apache.druid.java.util.emitter.core.NoopEmitter
- emit(Event) - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitter
- emit(Event) - Method in class org.apache.druid.java.util.emitter.core.SwitchingEmitter
-
Emit an event.
- emit(Event) - Method in class org.apache.druid.java.util.emitter.service.ServiceEmitter
- 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
- emit(ServiceEventBuilder<E>) - Method in class org.apache.druid.java.util.emitter.service.ServiceEmitter
- emitCPUTimeMetric(ServiceEmitter) - Method in class org.apache.druid.query.FluentQueryRunner
- emitCPUTimeMetric(ServiceEmitter, AtomicLong) - Method in class org.apache.druid.query.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.MetricsEmittingQueryProcessingPool
- emitter - Variable in class org.apache.druid.java.util.emitter.service.AlertBuilder
- Emitter - Interface in org.apache.druid.java.util.emitter.core
- EmitterFactory - Interface in org.apache.druid.java.util.emitter.factory
- Emitters - Class in org.apache.druid.java.util.emitter.core
- Emitters() - Constructor for class org.apache.druid.java.util.emitter.core.Emitters
- EmittingLogger - Class in org.apache.druid.java.util.emitter
- EmittingLogger(Class) - Constructor for class org.apache.druid.java.util.emitter.EmittingLogger
- EmittingLogger.EmittingAlertBuilder - Class in org.apache.druid.java.util.emitter
- empty() - Static method in class org.apache.druid.collections.spatial.ImmutableRTree
- empty() - Method in class org.apache.druid.extendedset.intset.ConciseSet
- empty() - Static method in class org.apache.druid.frame.key.RowKey
- empty() - Static method in class org.apache.druid.java.util.common.guava.Sequences
- empty() - Static method in class org.apache.druid.query.QueryContext
- empty() - Static method in class org.apache.druid.segment.column.RowSignature
- empty() - Static method in interface org.apache.druid.segment.data.Indexed
- empty() - Static method in interface org.apache.druid.segment.data.IndexedInts
- EMPTY - org.apache.druid.timeline.LogicalSegment.Status
- EMPTY - Static variable in class org.apache.druid.data.input.impl.DimensionsSpec
- EMPTY - Static variable in interface org.apache.druid.segment.data.BitmapValues
- EMPTY - Static variable in class org.apache.druid.segment.data.VSizeLongSerde
- EMPTY - Static variable in interface org.apache.druid.segment.serde.cell.StorableBuffer
- 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_BYTES - Static variable in class org.apache.druid.java.util.common.StringUtils
- EMPTY_ROW_INDEX - Static variable in class org.apache.druid.segment.incremental.IncrementalIndexRow
- EmptyIntIterator - Class in org.apache.druid.extendedset.intset
- EmptyRowsAndColumns - Class in org.apache.druid.query.rowsandcols
- EmptyRowsAndColumns() - Constructor for class org.apache.druid.query.rowsandcols.EmptyRowsAndColumns
- EMPTYSTRING - org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
- emptyToNullIfNeeded(String) - Static method in class org.apache.druid.common.config.NullHandling
- emptyToNullNonDruidDataString(String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Returns the given string if it is nonempty;
null
otherwise. - EMTPY - Static variable in class org.apache.druid.math.expr.Expr.BindingAnalysis
- ENABLE_DEBUG - Static variable in class org.apache.druid.query.QueryContexts
- 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
- encodeBase64(byte[]) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Convert an input byte array into a newly-allocated byte array using the
Base64
encoding scheme - encodeBase64String(byte[]) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Convert an input byte array into a string using the
Base64
encoding scheme - ENCODED_VALUE_COLUMN_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- EncodedKeyComponent<K> - Class in org.apache.druid.segment
-
Represents the encoded component of a row key corresponding to a single dimension.
- EncodedKeyComponent(K, long) - Constructor for class org.apache.druid.segment.EncodedKeyComponent
-
Creates an EncodedKeyComponent corresponding to a single dimension.
- EncodedStringDictionaryWriter - Class in org.apache.druid.segment.data
- EncodedStringDictionaryWriter(DictionaryWriter<byte[]>, StringEncodingStrategy) - Constructor for class org.apache.druid.segment.data.EncodedStringDictionaryWriter
- encodedValueSerializer - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- encodedValueSerializer - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- encodeForFormat(String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Encodes a string "s" for insertion into a format string.
- encounteredMultiValueRow - Variable in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
- encrypt(byte[]) - Method in class org.apache.druid.crypto.CryptoService
- end - Variable in class org.apache.druid.timeline.partition.BaseDimensionRangeShardSpec
- end(long) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- END_TIME - Static variable in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- enforceLogicalType() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- ensureShutdownHook() - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
- ensureSize(int) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
- ensureType(Frame) - Method in enum org.apache.druid.frame.FrameType
- enterAddSubExpr(ExprParser.AddSubExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
addSubExpr
labeled alternative inExprParser.expr()
. - enterAddSubExpr(ExprParser.AddSubExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
addSubExpr
labeled alternative inExprParser.expr()
. - enterApplyFunctionExpr(ExprParser.ApplyFunctionExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
applyFunctionExpr
labeled alternative inExprParser.expr()
. - enterApplyFunctionExpr(ExprParser.ApplyFunctionExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
applyFunctionExpr
labeled alternative inExprParser.expr()
. - enterDoubleArray(ExprParser.DoubleArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
doubleArray
labeled alternative inExprParser.expr()
. - enterDoubleArray(ExprParser.DoubleArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
doubleArray
labeled alternative inExprParser.expr()
. - enterDoubleExpr(ExprParser.DoubleExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
doubleExpr
labeled alternative inExprParser.expr()
. - enterDoubleExpr(ExprParser.DoubleExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
doubleExpr
labeled alternative inExprParser.expr()
. - enterEveryRule(ParserRuleContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
- enterExplicitArray(ExprParser.ExplicitArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
explicitArray
labeled alternative inExprParser.expr()
. - enterExplicitArray(ExprParser.ExplicitArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
explicitArray
labeled alternative inExprParser.expr()
. - enterExplicitLongArray(ExprParser.ExplicitLongArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
explicitLongArray
labeled alternative inExprParser.expr()
. - enterExplicitLongArray(ExprParser.ExplicitLongArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
explicitLongArray
labeled alternative inExprParser.expr()
. - enterExplicitStringArray(ExprParser.ExplicitStringArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
explicitStringArray
labeled alternative inExprParser.expr()
. - enterExplicitStringArray(ExprParser.ExplicitStringArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
explicitStringArray
labeled alternative inExprParser.expr()
. - enterFunctionArgs(ExprParser.FunctionArgsContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
functionArgs
labeled alternative inExprParser.fnArgs()
. - enterFunctionArgs(ExprParser.FunctionArgsContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
functionArgs
labeled alternative inExprParser.fnArgs()
. - enterFunctionExpr(ExprParser.FunctionExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
functionExpr
labeled alternative inExprParser.expr()
. - enterFunctionExpr(ExprParser.FunctionExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
functionExpr
labeled alternative inExprParser.expr()
. - enterIdentifierExpr(ExprParser.IdentifierExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
identifierExpr
labeled alternative inExprParser.expr()
. - enterIdentifierExpr(ExprParser.IdentifierExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
identifierExpr
labeled alternative inExprParser.expr()
. - enterLambda(ExprParser.LambdaContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by
ExprParser.lambda()
. - enterLambda(ExprParser.LambdaContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by
ExprParser.lambda()
. - enterLambda(ExprParser.LambdaContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- enterLiteralElement(ExprParser.LiteralElementContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by
ExprParser.literalElement()
. - enterLiteralElement(ExprParser.LiteralElementContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by
ExprParser.literalElement()
. - enterLogicalAndOrExpr(ExprParser.LogicalAndOrExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
logicalAndOrExpr
labeled alternative inExprParser.expr()
. - enterLogicalAndOrExpr(ExprParser.LogicalAndOrExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
logicalAndOrExpr
labeled alternative inExprParser.expr()
. - enterLogicalOpExpr(ExprParser.LogicalOpExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
logicalOpExpr
labeled alternative inExprParser.expr()
. - enterLogicalOpExpr(ExprParser.LogicalOpExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
logicalOpExpr
labeled alternative inExprParser.expr()
. - enterLongArray(ExprParser.LongArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
longArray
labeled alternative inExprParser.expr()
. - enterLongArray(ExprParser.LongArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
longArray
labeled alternative inExprParser.expr()
. - enterLongElement(ExprParser.LongElementContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by
ExprParser.longElement()
. - enterLongElement(ExprParser.LongElementContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by
ExprParser.longElement()
. - enterLongExpr(ExprParser.LongExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
longExpr
labeled alternative inExprParser.expr()
. - enterLongExpr(ExprParser.LongExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
longExpr
labeled alternative inExprParser.expr()
. - enterMulDivModuloExpr(ExprParser.MulDivModuloExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
mulDivModuloExpr
labeled alternative inExprParser.expr()
. - enterMulDivModuloExpr(ExprParser.MulDivModuloExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
mulDivModuloExpr
labeled alternative inExprParser.expr()
. - enterNestedExpr(ExprParser.NestedExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
nestedExpr
labeled alternative inExprParser.expr()
. - enterNestedExpr(ExprParser.NestedExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
nestedExpr
labeled alternative inExprParser.expr()
. - enterNull(ExprParser.NullContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
null
labeled alternative inExprParser.expr()
. - enterNull(ExprParser.NullContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
null
labeled alternative inExprParser.expr()
. - enterNumericElement(ExprParser.NumericElementContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by
ExprParser.numericElement()
. - enterNumericElement(ExprParser.NumericElementContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by
ExprParser.numericElement()
. - enterPowOpExpr(ExprParser.PowOpExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
powOpExpr
labeled alternative inExprParser.expr()
. - enterPowOpExpr(ExprParser.PowOpExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
powOpExpr
labeled alternative inExprParser.expr()
. - enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.AddSubExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ApplyFunctionExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.DoubleArrayContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.DoubleExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitArrayContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitLongArrayContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitStringArrayContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.FunctionArgsContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.FunctionExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.IdentifierExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LambdaContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LiteralElementContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LogicalAndOrExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LogicalOpExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongArrayContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongElementContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.MulDivModuloExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.NestedExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.NullContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.NumericElementContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.PowOpExprContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StartContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringArrayContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringElementContext
- enterRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.UnaryOpExprContext
- enterStart(ExprParser.StartContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by
ExprParser.start()
. - enterStart(ExprParser.StartContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by
ExprParser.start()
. - enterString(ExprParser.StringContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
string
labeled alternative inExprParser.expr()
. - enterString(ExprParser.StringContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
string
labeled alternative inExprParser.expr()
. - enterStringArray(ExprParser.StringArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
stringArray
labeled alternative inExprParser.expr()
. - enterStringArray(ExprParser.StringArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
stringArray
labeled alternative inExprParser.expr()
. - enterStringElement(ExprParser.StringElementContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by
ExprParser.stringElement()
. - enterStringElement(ExprParser.StringElementContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by
ExprParser.stringElement()
. - enterUnaryOpExpr(ExprParser.UnaryOpExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Enter a parse tree produced by the
unaryOpExpr
labeled alternative inExprParser.expr()
. - enterUnaryOpExpr(ExprParser.UnaryOpExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Enter a parse tree produced by the
unaryOpExpr
labeled alternative inExprParser.expr()
. - EntireLayoutColumnarDoublesSerializer - Class in org.apache.druid.segment.data
-
Serializer that produces
EntireLayoutColumnarDoublesSupplier.EntireLayoutColumnarDoubles
. - 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
-
Serializer that produces
EntireLayoutColumnarFloatsSupplier.EntireLayoutColumnarFloats
. - 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
-
Serializer that produces
EntireLayoutColumnarLongsSupplier.EntireLayoutColumnarLongs
. - EntireLayoutColumnarLongsSupplier - Class in org.apache.druid.segment.data
- EntireLayoutColumnarLongsSupplier(int, CompressionFactory.LongEncodingReader) - Constructor for class org.apache.druid.segment.data.EntireLayoutColumnarLongsSupplier
- EntryAlreadyExists - Class in org.apache.druid.error
-
A failure type used to make
DruidException
s of categoryDruidException.Category.INVALID_INPUT
for personaDruidException.Persona.USER
, denoting that a certain entry already exists. - EntryAlreadyExists(Throwable, String, Object...) - Constructor for class org.apache.druid.error.EntryAlreadyExists
- EntrySpan(int, int) - Constructor for class org.apache.druid.segment.serde.cell.IntIndexView.EntrySpan
- ENUMERATED - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- 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
- EnvironmentVariableDynamicConfigProvider - Class in org.apache.druid.metadata
- EnvironmentVariableDynamicConfigProvider(Map<String, String>) - Constructor for class org.apache.druid.metadata.EnvironmentVariableDynamicConfigProvider
- EnvironmentVariablePasswordProvider - Class in org.apache.druid.metadata
- EnvironmentVariablePasswordProvider(String) - Constructor for class org.apache.druid.metadata.EnvironmentVariablePasswordProvider
- EOF() - Method in class org.apache.druid.math.expr.antlr.ExprParser.StartContext
- EPOCH - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- EPOCH - Static variable in class org.apache.druid.java.util.common.DateTimes
- EQ - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- EQ - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- equal(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorComparisonProcessors
- 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, boolean) - Constructor for class org.apache.druid.segment.join.Equality
- EqualityFilter - Class in org.apache.druid.query.filter
- EqualityFilter(String, ColumnType, Object, FilterTuning) - Constructor for class org.apache.druid.query.filter.EqualityFilter
- EqualityFilter.EqualityPredicateFactory - Class in org.apache.druid.query.filter
- EqualityFilter.TypedConstantValueMatcherFactory - Class in org.apache.druid.query.filter
- equalityHash() - Method in class org.apache.druid.segment.nested.StructuredData
- EqualityPredicateFactory(ExprEval<?>) - Constructor for class org.apache.druid.query.filter.EqualityFilter.EqualityPredicateFactory
- equals(Double, Double) - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- equals(Float, Float) - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- equals(Long, Long) - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- equals(Object) - Method in class org.apache.druid.audit.AuditEntry
- equals(Object) - Method in class org.apache.druid.audit.AuditEntry.Payload
- equals(Object) - Method in class org.apache.druid.audit.AuditInfo
- equals(Object) - Method in class org.apache.druid.audit.RequestInfo
- equals(Object) - Method in class org.apache.druid.collections.RangeIntSet
- 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.common.exception.AllowedRegexErrorResponseTransformStrategy
- equals(Object) - Method in class org.apache.druid.common.exception.NoErrorResponseTransformStrategy
- equals(Object) - Method in class org.apache.druid.data.input.ColumnsFilter.ExclusionBased
- equals(Object) - Method in class org.apache.druid.data.input.ColumnsFilter.InclusionBased
- equals(Object) - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- equals(Object) - Method in class org.apache.druid.data.input.impl.CloudObjectLocation
- equals(Object) - Method in class org.apache.druid.data.input.impl.CombiningInputSource
- equals(Object) - Method in class org.apache.druid.data.input.impl.DimensionSchema
- equals(Object) - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- equals(Object) - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- equals(Object) - Method in class org.apache.druid.data.input.impl.HttpInputSource
- equals(Object) - Method in class org.apache.druid.data.input.impl.HttpInputSourceConfig
- equals(Object) - Method in class org.apache.druid.data.input.impl.InlineInputSource
- equals(Object) - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- equals(Object) - Method in class org.apache.druid.data.input.impl.JSONParseSpec
- equals(Object) - Method in class org.apache.druid.data.input.impl.LocalInputSource
- equals(Object) - Method in class org.apache.druid.data.input.impl.NestedDataParseSpec
- equals(Object) - Method in class org.apache.druid.data.input.impl.NestedInputFormat
- equals(Object) - Method in class org.apache.druid.data.input.impl.NewSpatialDimensionSchema
- equals(Object) - Method in class org.apache.druid.data.input.impl.NoopInputRowParser
- equals(Object) - Method in class org.apache.druid.data.input.impl.ParseSpec
-
Deprecated.
- equals(Object) - Method in class org.apache.druid.data.input.impl.SpatialDimensionSchema
-
Deprecated.
- equals(Object) - Method in class org.apache.druid.data.input.impl.systemfield.SystemFields
- equals(Object) - Method in class org.apache.druid.data.input.impl.TimestampSpec
- equals(Object) - Method in class org.apache.druid.data.input.ListBasedInputRow
- equals(Object) - Method in class org.apache.druid.data.input.MapBasedInputRow
- equals(Object) - Method in class org.apache.druid.data.input.MapBasedRow
- equals(Object) - Method in class org.apache.druid.data.input.MaxSizeSplitHintSpec
- equals(Object) - Method in class org.apache.druid.data.input.SegmentsSplitHintSpec
- equals(Object) - Method in class org.apache.druid.data.input.StringTuple
- equals(Object) - Method in class org.apache.druid.extendedset.intset.AbstractIntSet
- equals(Object) - Method in class org.apache.druid.extendedset.intset.ConciseSet
- equals(Object) - Method in class org.apache.druid.frame.key.ByteRowKeyComparator
- equals(Object) - Method in class org.apache.druid.frame.key.ClusterBy
- equals(Object) - Method in class org.apache.druid.frame.key.ClusterByPartition
- equals(Object) - Method in class org.apache.druid.frame.key.ClusterByPartitions
- equals(Object) - Method in class org.apache.druid.frame.key.KeyColumn
- equals(Object) - Method in class org.apache.druid.frame.key.RowKey
- equals(Object) - Method in class org.apache.druid.frame.key.RowKeyComparator
- equals(Object) - Method in class org.apache.druid.frame.key.RowKeyComparisonRunLengths
- equals(Object) - Method in class org.apache.druid.frame.key.RunLengthEntry
- equals(Object) - Method in class org.apache.druid.frame.processor.ReturnOrAwait
- equals(Object) - Method in class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- equals(Object) - Method in exception org.apache.druid.frame.write.InvalidFieldException
- equals(Object) - Method in class org.apache.druid.hll.HyperLogLogCollector
- equals(Object) - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- equals(Object) - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- equals(Object) - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- equals(Object) - Method in class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
- equals(Object) - Method in class org.apache.druid.indexer.Property
- equals(Object) - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- equals(Object) - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrorsTaskReport
- equals(Object) - Method in class org.apache.druid.indexer.report.KillTaskReport
- equals(Object) - Method in class org.apache.druid.indexer.report.KillTaskReport.Stats
- equals(Object) - Method in class org.apache.druid.indexer.report.TaskContextReport
- equals(Object) - Method in class org.apache.druid.indexer.TaskIdentifier
- equals(Object) - Method in class org.apache.druid.indexer.TaskLocation
- equals(Object) - Method in class org.apache.druid.indexer.TaskStatus
- equals(Object) - Method in class org.apache.druid.indexer.TaskStatusPlus
- equals(Object) - Method in class org.apache.druid.jackson.DefaultTrueJsonIncludeFilter
- equals(Object) - Method in class org.apache.druid.java.util.common.Either
- equals(Object) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- equals(Object) - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- equals(Object) - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- equals(Object) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- equals(Object) - Method in class org.apache.druid.java.util.common.HumanReadableBytes
- equals(Object) - Method in class org.apache.druid.java.util.common.NonnullPair
- equals(Object) - Method in class org.apache.druid.java.util.common.Pair
- equals(Object) - Method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- equals(Object) - Method in class org.apache.druid.java.util.common.parsers.JSONPathSpec
- equals(Object) - Method in class org.apache.druid.java.util.common.StringEncodingDefaultUTF16LEJsonIncludeFilter
- equals(Object) - Method in class org.apache.druid.java.util.common.Triple
- equals(Object) - Method in class org.apache.druid.js.JavaScriptConfig
- equals(Object) - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- equals(Object) - Method in class org.apache.druid.metadata.DefaultPasswordProvider
- equals(Object) - Method in class org.apache.druid.metadata.EnvironmentVariableDynamicConfigProvider
- equals(Object) - Method in class org.apache.druid.metadata.EnvironmentVariablePasswordProvider
- equals(Object) - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- equals(Object) - Method in class org.apache.druid.metadata.TaskLookup.ActiveTaskLookup
- equals(Object) - Method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- 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.ExpressionLambdaAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- equals(Object) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.mean.DoubleMeanAggregatorFactory
- 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.SingleValueAggregatorFactory
- 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.ArrayContainsElementFilter
- 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.EqualityFilter.EqualityPredicateFactory
- equals(Object) - Method in class org.apache.druid.query.filter.EqualityFilter
- 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.IsBooleanDimFilter
- 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.NullFilter
- equals(Object) - Method in class org.apache.druid.query.filter.NullFilter.NullPredicateFactory
- equals(Object) - Method in class org.apache.druid.query.filter.OrDimFilter
- equals(Object) - Method in class org.apache.druid.query.filter.RangeFilter
- 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.StringPredicateDruidPredicateFactory
- equals(Object) - Method in class org.apache.druid.query.filter.TrueDimFilter
- equals(Object) - Method in class org.apache.druid.query.filter.TypedInFilter
- equals(Object) - Method in class org.apache.druid.query.filter.TypedInFilter.PredicateFactory
- equals(Object) - Method in class org.apache.druid.query.FilteredDataSource
- equals(Object) - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
- equals(Object) - Method in class org.apache.druid.query.groupby.epinephelinae.IntKey
- 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.DefaultLimitSpec.LimitJsonIncludeFilter
- 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.operator.ColumnWithDirection
- equals(Object) - Method in class org.apache.druid.query.operator.NaivePartitioningOperatorFactory
- equals(Object) - Method in class org.apache.druid.query.operator.NaiveSortOperatorFactory
- equals(Object) - Method in class org.apache.druid.query.operator.OffsetLimit
- equals(Object) - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- equals(Object) - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- equals(Object) - Method in class org.apache.druid.query.operator.window.ranking.WindowRankProcessor
- equals(Object) - Method in class org.apache.druid.query.operator.window.WindowFrame
- equals(Object) - Method in class org.apache.druid.query.operator.window.WindowFramedAggregateProcessor
- equals(Object) - Method in class org.apache.druid.query.operator.window.WindowOperatorFactory
- equals(Object) - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- 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.NaturalComparator
- 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.QueryContext
- equals(Object) - Method in class org.apache.druid.query.QueryDataSource
- equals(Object) - Method in class org.apache.druid.query.QueryResourceId
- 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.ScanQuery.OrderBy
- 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.SegmentDescriptor
- 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.query.UnnestDataSource
- equals(Object) - Method in class org.apache.druid.segment.AutoTypeColumnSchema
- equals(Object) - Method in class org.apache.druid.segment.column.BaseTypeSignature
- equals(Object) - Method in class org.apache.druid.segment.column.RowSignature
- equals(Object) - Method in class org.apache.druid.segment.column.SimpleColumnIndexCapabilities
- equals(Object) - Method in class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- equals(Object) - Method in class org.apache.druid.segment.column.StringEncodingStrategy.Utf8
- 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.DataSegmentsWithSchemas
- equals(Object) - Method in class org.apache.druid.segment.DefaultColumnFormatConfig
- 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.IsBooleanFilter
- 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.incremental.OnheapIncrementalIndex.Spec
- equals(Object) - Method in class org.apache.druid.segment.incremental.ParseExceptionReport
- equals(Object) - Method in class org.apache.druid.segment.incremental.RowIngestionMetersTotals
- 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.nested.FieldTypeInfo.MutableTypeSet
- equals(Object) - Method in class org.apache.druid.segment.nested.FieldTypeInfo.TypeSet
- equals(Object) - Method in class org.apache.druid.segment.nested.NestedPathArrayElement
- equals(Object) - Method in class org.apache.druid.segment.nested.NestedPathField
- equals(Object) - Method in class org.apache.druid.segment.nested.StructuredData
- equals(Object) - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessedValue
- equals(Object) - Method in class org.apache.druid.segment.NestedDataColumnSchema
- equals(Object) - Method in class org.apache.druid.segment.SchemaPayload
- equals(Object) - Method in class org.apache.druid.segment.SchemaPayloadPlus
- equals(Object) - Method in class org.apache.druid.segment.SegmentMetadata
- equals(Object) - Method in class org.apache.druid.segment.SegmentSchemaMapping
- equals(Object) - Method in class org.apache.druid.segment.serde.NullColumnPartSerde
- 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.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.virtual.ListFilteredVirtualColumn
- equals(Object) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- equals(Object) - Method in class org.apache.druid.segment.VirtualColumns
- equals(Object) - Method in class org.apache.druid.segment.VirtualColumns.JsonIncludeFilter
- equals(Object) - Method in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- equals(Object) - Method in class org.apache.druid.storage.local.LocalFileStorageConnectorProvider
- equals(Object) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- equals(Object) - Method in class org.apache.druid.timeline.CompactionState
- equals(Object) - Method in class org.apache.druid.timeline.DataSegment
- equals(Object) - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- equals(Object) - Method in class org.apache.druid.timeline.partition.LinearPartitionChunk
- equals(Object) - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- equals(Object) - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- equals(Object) - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- equals(Object) - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.PartitionBoundaries
- equals(Object) - Method in class org.apache.druid.timeline.partition.PartitionHolder
- equals(Object) - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- equals(Object) - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- equals(Object) - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- equals(Object) - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- equals(Object) - Method in class org.apache.druid.timeline.SegmentId
- equals(Object) - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- equals(Object) - Method in class org.apache.druid.timeline.TimelineObjectHolder
- equals(Object) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline.TimelineEntry
- equals(Object[], Object[]) - Method in class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
-
Implements
Arrays.equals(long[], long[])
but the element equality uses the element's type strategy - equals(String, String) - Method in class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- equals(T, T) - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- equals(T, T) - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- equals(T, T) - Method in interface org.apache.druid.segment.column.TypeStrategy
- equalTo(long, Object, long, long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- equalTo(long, Object, long, long) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- equalTo(String) - Static method in class org.apache.druid.query.filter.StringPredicateDruidPredicateFactory
- equalTo(T) - Static method in interface org.apache.druid.query.filter.DruidObjectPredicate
- 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() - Method in class org.apache.druid.java.util.common.Either
-
Returns the error object.
- error(String) - Static method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- error(String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- error(String, Throwable) - Method in class org.apache.druid.java.util.common.logger.Logger
-
Deprecated.
- error(Throwable, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- error(L) - Static method in class org.apache.druid.java.util.common.Either
- error(Marker, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- ERROR - org.apache.druid.java.util.emitter.core.LoggingEmitter.Level
- ERROR_CLASS - Static variable in exception org.apache.druid.query.BadJsonQueryException
- ERROR_CLASS - Static variable in exception org.apache.druid.query.BadQueryContextException
- ERROR_CODE - Static variable in class org.apache.druid.error.EntryAlreadyExists
- ERROR_CODE - Static variable in class org.apache.druid.error.QueryExceptionCompat
- ERROR_MESSAGE - Static variable in exception org.apache.druid.query.QueryTimeoutException
- errorMsg(String) - Method in class org.apache.druid.frame.write.InvalidFieldException.Builder
- ErrorResponse - Class in org.apache.druid.error
-
A Response Object that represents an error to be returned over the wire.
- ErrorResponse(DruidException) - Constructor for class org.apache.druid.error.ErrorResponse
- ErrorResponseTransformStrategy - Interface in org.apache.druid.common.exception
- errorSegments(Collection<DataSegment>, String) - Method in class org.apache.druid.java.util.common.logger.Logger
- EscalatedGlobal - Annotation Type in org.apache.druid.guice.annotations
- estimateByteBuffer(ByteBuffer) - Static method in class org.apache.druid.hll.HyperLogLogCollector
- 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() - Method in class org.apache.druid.hll.HyperLogLogCollector
- estimateCardinality(Object, boolean) - Static method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
- estimateCardinalityRound() - Method in class org.apache.druid.hll.HyperLogLogCollector
- estimatedBinaryLengthAsUTF8(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- estimatedFieldKeySize - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
- estimatedObjectSizeBytes() - Method in class org.apache.druid.frame.key.RowKey
-
Estimate number of bytes taken by the key array.
- estimateEncodedKeyComponentSize(int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
-
Estimates size of the given key component.
- estimateEntryFootprint(int) - Static method in class org.apache.druid.query.groupby.epinephelinae.DictionaryBuildingUtils
-
Estimated footprint of a new entry.
- estimateHeapFootprint() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
- estimateHeapFootprint() - Method in class org.apache.druid.query.lookup.ImmutableLookupMap.ImmutableLookupExtractor
- estimateHeapFootprint() - Method in class org.apache.druid.query.lookup.LookupExtractor
-
Estimated heap footprint of this object.
- estimateHeapFootprint(Iterable<Map.Entry<K, V>>) - Static method in class org.apache.druid.query.extraction.MapLookupExtractor
-
Estimate the heap footprint of a Map.
- estimateNumSplits(InputFormat, SplitHintSpec) - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- estimateNumSplits(InputFormat, SplitHintSpec) - Method in class org.apache.druid.data.input.impl.CombiningInputSource
- estimateNumSplits(InputFormat, SplitHintSpec) - Method in class org.apache.druid.data.input.impl.HttpInputSource
- estimateNumSplits(InputFormat, SplitHintSpec) - Method in class org.apache.druid.data.input.impl.LocalInputSource
- estimateNumSplits(InputFormat, SplitHintSpec) - Method in interface org.apache.druid.data.input.impl.SplittableInputSource
-
Returns an estimated total number of splits to be created via
SplittableInputSource.createSplits(org.apache.druid.data.input.InputFormat, org.apache.druid.data.input.SplitHintSpec)
. - estimateSizeBytes(Double) - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- estimateSizeBytes(Float) - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- estimateSizeBytes(Long) - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- estimateSizeBytes(Object[]) - Method in class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
- estimateSizeBytes(String) - Method in class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- estimateSizeBytes(T) - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- estimateSizeBytes(T) - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- estimateSizeBytes(T) - Method in interface org.apache.druid.segment.column.TypeStrategy
-
Estimate the size in bytes that writing this value to memory would require.
- estimateSizeOfValue(String) - Method in class org.apache.druid.segment.StringDimensionDictionary
- estimateSizeOfValue(T) - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
-
Estimates the size of the dimension value in bytes.
- estimateSizeOfValue(T) - Method in class org.apache.druid.segment.DimensionDictionary
-
Estimates the size of the dimension value in bytes.
- estimateStringSize(String) - Static method in class org.apache.druid.segment.nested.StructuredDataProcessor
-
this is copied from
StringDimensionDictionary.estimateSizeOfValue(String)
- ETAG - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
Entity tag.
- ETERNITY - Static variable in class org.apache.druid.java.util.common.Intervals
- eternityInterval() - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
-
Convenience method for an interval over all time.
- euclidean - org.apache.druid.collections.spatial.search.RadiusBound.RadiusUnit
- eval() - Method in class org.apache.druid.segment.virtual.BaseExpressionColumnValueSelector
-
Implementations override this.
- eval() - Method in class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
- eval() - Method in class org.apache.druid.segment.virtual.RowBasedExpressionColumnValueSelector
- eval() - Method in class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
- eval() - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
- eval(double) - Method in class org.apache.druid.math.expr.Function.Abs
- eval(double) - Method in class org.apache.druid.math.expr.Function.Acos
- eval(double) - Method in class org.apache.druid.math.expr.Function.Asin
- eval(double) - Method in class org.apache.druid.math.expr.Function.Atan
- eval(double) - Method in class org.apache.druid.math.expr.Function.BitwiseConvertDoubleToLongBits
- eval(double) - Method in class org.apache.druid.math.expr.Function.Cbrt
- eval(double) - Method in class org.apache.druid.math.expr.Function.Ceil
- eval(double) - Method in class org.apache.druid.math.expr.Function.Cos
- eval(double) - Method in class org.apache.druid.math.expr.Function.Cosh
- eval(double) - Method in class org.apache.druid.math.expr.Function.Cot
- eval(double) - Method in class org.apache.druid.math.expr.Function.Exp
- eval(double) - Method in class org.apache.druid.math.expr.Function.Expm1
- eval(double) - Method in class org.apache.druid.math.expr.Function.Floor
- eval(double) - Method in class org.apache.druid.math.expr.Function.GetExponent
- eval(double) - Method in class org.apache.druid.math.expr.Function.Log
- eval(double) - Method in class org.apache.druid.math.expr.Function.Log10
- eval(double) - Method in class org.apache.druid.math.expr.Function.Log1p
- eval(double) - Method in class org.apache.druid.math.expr.Function.NextUp
- eval(double) - Method in class org.apache.druid.math.expr.Function.Rint
- eval(double) - Method in class org.apache.druid.math.expr.Function.Signum
- eval(double) - Method in class org.apache.druid.math.expr.Function.Sin
- eval(double) - Method in class org.apache.druid.math.expr.Function.Sinh
- eval(double) - Method in class org.apache.druid.math.expr.Function.Sqrt
- eval(double) - Method in class org.apache.druid.math.expr.Function.Tan
- eval(double) - Method in class org.apache.druid.math.expr.Function.Tanh
- eval(double) - Method in class org.apache.druid.math.expr.Function.ToDegrees
- eval(double) - Method in class org.apache.druid.math.expr.Function.ToRadians
- eval(double) - Method in class org.apache.druid.math.expr.Function.Ulp
- eval(double) - Method in class org.apache.druid.math.expr.Function.UnivariateMathFunction
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.Atan2
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.BivariateMathFunction
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.CopySign
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.Div
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.Hypot
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.Max
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.Min
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.NextAfter
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.Pow
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.Remainder
- eval(double, double) - Method in class org.apache.druid.math.expr.Function.SafeDivide
- eval(long) - Method in class org.apache.druid.math.expr.Function.Abs
- eval(long) - Method in class org.apache.druid.math.expr.Function.BitwiseComplement
- eval(long) - Method in class org.apache.druid.math.expr.Function.BitwiseConvertLongBitsToDouble
- eval(long) - Method in class org.apache.druid.math.expr.Function.UnivariateMathFunction
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.BitwiseAnd
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.BitwiseOr
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.BitwiseShiftLeft
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.BitwiseShiftRight
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.BitwiseXor
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.BivariateBitwiseMathFunction
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.BivariateMathFunction
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.Div
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.Max
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.Min
- eval(long, long) - Method in class org.apache.druid.math.expr.Function.SafeDivide
- eval(String, int) - Method in class org.apache.druid.math.expr.Function.LeftFunc
- eval(String, int) - Method in class org.apache.druid.math.expr.Function.RepeatFunc
- eval(String, int) - Method in class org.apache.druid.math.expr.Function.RightFunc
- eval(String, int) - Method in class org.apache.druid.math.expr.Function.StringLongFunction
- eval(Row) - Method in interface org.apache.druid.segment.transform.RowFunction
- eval(Expr.ObjectBinding) - Method in interface org.apache.druid.math.expr.Expr
- eval(Expr.ObjectBinding) - Method in class org.apache.druid.query.expression.TimestampExtractExprMacro.TimestampExtractDynamicExpr
- eval(Expr.ObjectBinding) - Method in class org.apache.druid.query.expression.TimestampExtractExprMacro.TimestampExtractExpr
- 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(ExprEval) - Method in class org.apache.druid.math.expr.Function.ReverseFunc
- eval(ExprEval) - Method in class org.apache.druid.math.expr.Function.UnivariateFunction
- eval(ExprEval) - Method in class org.apache.druid.math.expr.Function.UnivariateMathFunction
- eval(ExprEval, ExprEval) - Method in class org.apache.druid.math.expr.Function.BivariateBitwiseMathFunction
- eval(ExprEval, ExprEval) - Method in class org.apache.druid.math.expr.Function.BivariateFunction
- eval(ExprEval, ExprEval) - Method in class org.apache.druid.math.expr.Function.BivariateMathFunction
- eval(ExprEval, ExprEval) - Method in class org.apache.druid.math.expr.Function.CastFunc
- eval(ExprEval, ExprEval) - Method in class org.apache.druid.math.expr.Function.Scalb
- eval(ExprEval, ExprEval) - Method in class org.apache.druid.math.expr.Function.StringLongFunction
- 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
- evalDimension(Row) - Method in interface org.apache.druid.segment.transform.RowFunction
- Evals - Class in org.apache.druid.math.expr
- Evals() - Constructor for class org.apache.druid.math.expr.Evals
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.BivariateDoubleFunctionVectorValueProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.BivariateFunctionVectorObjectProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.BivariateFunctionVectorProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.BivariateLongFunctionVectorValueProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.CastToDoubleVectorProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.CastToLongVectorProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.CastToStringVectorProcessor
- evalVector(Expr.VectorInputBinding) - Method in interface org.apache.druid.math.expr.vector.ExprVectorProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.ObjectOutMultiObjectInVectorProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.UnivariateDoubleFunctionVectorValueProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.UnivariateFunctionVectorObjectProcessor
- evalVector(Expr.VectorInputBinding) - Method in class org.apache.druid.math.expr.vector.UnivariateLongFunctionVectorValueProcessor
- Event - Interface in org.apache.druid.java.util.emitter.core
- EventMap - Class in org.apache.druid.java.util.emitter.core
-
EventMap is a hash map implementation.
- EventMap() - Constructor for class org.apache.druid.java.util.emitter.core.EventMap
- EventMap.Builder - Class in org.apache.druid.java.util.emitter.core
- EventMapSerializer - Class in org.apache.druid.java.util.emitter.core
- EventMapSerializer() - Constructor for class org.apache.druid.java.util.emitter.core.EventMapSerializer
- EverythingIsNonnullByDefault - Annotation Type in org.apache.druid.annotations
-
This annotation can be applied to a package, class or method to indicate that all class fields and method parameters and return values in that element are nonnull by default unless overridden.
- exception() - Static method in class org.apache.druid.error.Forbidden
- exception(String, Object...) - Static method in class org.apache.druid.error.EntryAlreadyExists
- exception(String, Object...) - Static method in class org.apache.druid.error.Forbidden
- exception(String, Object...) - Static method in class org.apache.druid.error.InternalServerError
- exception(String, Object...) - Static method in class org.apache.druid.error.InvalidInput
- exception(String, Object...) - Static method in class org.apache.druid.error.InvalidSqlInput
- exception(String, Object...) - Static method in class org.apache.druid.error.NotFound
- exception(Throwable, String, Object...) - Static method in class org.apache.druid.error.EntryAlreadyExists
- exception(Throwable, String, Object...) - Static method in class org.apache.druid.error.Forbidden
- exception(Throwable, String, Object...) - Static method in class org.apache.druid.error.InternalServerError
- exception(Throwable, String, Object...) - Static method in class org.apache.druid.error.InvalidInput
- exception(Throwable, String, Object...) - Static method in class org.apache.druid.error.InvalidSqlInput
- exception(Throwable, String, Object...) - Static method in class org.apache.druid.error.NotFound
- EXCEPTION_MESSAGE_KEY - Static variable in class org.apache.druid.java.util.emitter.service.AlertBuilder
- EXCEPTION_STACK_TRACE_KEY - Static variable in class org.apache.druid.java.util.emitter.service.AlertBuilder
- EXCEPTION_TYPE_KEY - Static variable in class org.apache.druid.java.util.emitter.service.AlertBuilder
- exceptionCaught(Throwable) - Method in class org.apache.druid.java.util.http.client.io.AppendableByteArrayInputStream
- exceptionCaught(Throwable) - Method in class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHolder
- exceptionCaught(ClientResponse<IntermediateType>, Throwable) - Method in interface org.apache.druid.java.util.http.client.response.HttpResponseHandler
- exceptionCaught(ClientResponse<InputStream>, Throwable) - Method in class org.apache.druid.java.util.http.client.response.SequenceInputStreamResponseHandler
- exceptionCaught(ClientResponse<FrameFilePartialFetch>, Throwable) - Method in class org.apache.druid.frame.file.FrameFileHttpResponseHandler
- exceptionCaught(ClientResponse<Either<StringFullResponseHolder, IntermediateType>>, Throwable) - Method in class org.apache.druid.java.util.http.client.response.ObjectOrErrorResponseHandler
- exceptionCaught(ClientResponse<AppendableByteArrayInputStream>, Throwable) - Method in class org.apache.druid.java.util.http.client.response.InputStreamResponseHandler
- exceptionCaught(ClientResponse<BytesFullResponseHolder>, Throwable) - Method in class org.apache.druid.java.util.http.client.response.BytesFullResponseHandler
- exceptionCaught(ClientResponse<InputStreamFullResponseHolder>, Throwable) - Method in class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHandler
- exceptionCaught(ClientResponse<StatusResponseHolder>, Throwable) - Method in class org.apache.druid.java.util.http.client.response.StatusResponseHandler
- exceptionCaught(ClientResponse<StringFullResponseHolder>, Throwable) - Method in class org.apache.druid.java.util.http.client.response.StringFullResponseHandler
- exclusionBased(Set<String>) - Static method in class org.apache.druid.data.input.ColumnsFilter
-
Accepts all columns, except those on a specific list.
- ExclusionBased(Set<String>) - Constructor for class org.apache.druid.data.input.ColumnsFilter.ExclusionBased
- Execs - Class in org.apache.druid.java.util.common.concurrent
- Execs() - Constructor for class org.apache.druid.java.util.common.concurrent.Execs
- execute() - Method in interface org.apache.druid.segment.SegmentLazyLoadFailCallback
- 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
- execute(Runnable) - Method in class org.apache.druid.java.util.common.concurrent.DirectExecutorService
- execute(Runnable) - Method in class org.apache.druid.query.PrioritizedExecutorService
- ExecuteWhenDoneYielder<T> - Class in org.apache.druid.java.util.common.guava
- ExecuteWhenDoneYielder(Yielder<T>, Runnable, Executor) - Constructor for class org.apache.druid.java.util.common.guava.ExecuteWhenDoneYielder
- ExecutionMode - Enum in org.apache.druid.query
- ExecutorServiceMonitor - Class in org.apache.druid.query
- ExecutorServiceMonitor() - Constructor for class org.apache.druid.query.ExecutorServiceMonitor
- ExecutorServiceMonitor.MetricEmitter - Interface in org.apache.druid.query
- ExecutorServices - Class in org.apache.druid.java.util.common.concurrent
- ExecutorServices() - Constructor for class org.apache.druid.java.util.common.concurrent.ExecutorServices
- exists(String) - Method in class org.apache.druid.segment.VirtualColumns
-
Returns true if a virtual column exists with a particular columnName.
- exitAddSubExpr(ExprParser.AddSubExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
addSubExpr
labeled alternative inExprParser.expr()
. - exitAddSubExpr(ExprParser.AddSubExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
addSubExpr
labeled alternative inExprParser.expr()
. - exitAddSubExpr(ExprParser.AddSubExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitApplyFunctionExpr(ExprParser.ApplyFunctionExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
applyFunctionExpr
labeled alternative inExprParser.expr()
. - exitApplyFunctionExpr(ExprParser.ApplyFunctionExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
applyFunctionExpr
labeled alternative inExprParser.expr()
. - exitApplyFunctionExpr(ExprParser.ApplyFunctionExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitDoubleArray(ExprParser.DoubleArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
doubleArray
labeled alternative inExprParser.expr()
. - exitDoubleArray(ExprParser.DoubleArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
doubleArray
labeled alternative inExprParser.expr()
. - exitDoubleArray(ExprParser.DoubleArrayContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitDoubleExpr(ExprParser.DoubleExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
doubleExpr
labeled alternative inExprParser.expr()
. - exitDoubleExpr(ExprParser.DoubleExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
doubleExpr
labeled alternative inExprParser.expr()
. - exitDoubleExpr(ExprParser.DoubleExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitEveryRule(ParserRuleContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
- exitExplicitArray(ExprParser.ExplicitArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
explicitArray
labeled alternative inExprParser.expr()
. - exitExplicitArray(ExprParser.ExplicitArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
explicitArray
labeled alternative inExprParser.expr()
. - exitExplicitArray(ExprParser.ExplicitArrayContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitExplicitLongArray(ExprParser.ExplicitLongArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
explicitLongArray
labeled alternative inExprParser.expr()
. - exitExplicitLongArray(ExprParser.ExplicitLongArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
explicitLongArray
labeled alternative inExprParser.expr()
. - exitExplicitLongArray(ExprParser.ExplicitLongArrayContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitExplicitStringArray(ExprParser.ExplicitStringArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
explicitStringArray
labeled alternative inExprParser.expr()
. - exitExplicitStringArray(ExprParser.ExplicitStringArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
explicitStringArray
labeled alternative inExprParser.expr()
. - exitExplicitStringArray(ExprParser.ExplicitStringArrayContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitFunctionArgs(ExprParser.FunctionArgsContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
functionArgs
labeled alternative inExprParser.fnArgs()
. - exitFunctionArgs(ExprParser.FunctionArgsContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
functionArgs
labeled alternative inExprParser.fnArgs()
. - exitFunctionArgs(ExprParser.FunctionArgsContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitFunctionExpr(ExprParser.FunctionExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
functionExpr
labeled alternative inExprParser.expr()
. - exitFunctionExpr(ExprParser.FunctionExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
functionExpr
labeled alternative inExprParser.expr()
. - exitFunctionExpr(ExprParser.FunctionExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitIdentifierExpr(ExprParser.IdentifierExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
identifierExpr
labeled alternative inExprParser.expr()
. - exitIdentifierExpr(ExprParser.IdentifierExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
identifierExpr
labeled alternative inExprParser.expr()
. - exitIdentifierExpr(ExprParser.IdentifierExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitLambda(ExprParser.LambdaContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by
ExprParser.lambda()
. - exitLambda(ExprParser.LambdaContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by
ExprParser.lambda()
. - exitLambda(ExprParser.LambdaContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitLiteralElement(ExprParser.LiteralElementContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by
ExprParser.literalElement()
. - exitLiteralElement(ExprParser.LiteralElementContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by
ExprParser.literalElement()
. - exitLogicalAndOrExpr(ExprParser.LogicalAndOrExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
logicalAndOrExpr
labeled alternative inExprParser.expr()
. - exitLogicalAndOrExpr(ExprParser.LogicalAndOrExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
logicalAndOrExpr
labeled alternative inExprParser.expr()
. - exitLogicalAndOrExpr(ExprParser.LogicalAndOrExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitLogicalOpExpr(ExprParser.LogicalOpExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
logicalOpExpr
labeled alternative inExprParser.expr()
. - exitLogicalOpExpr(ExprParser.LogicalOpExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
logicalOpExpr
labeled alternative inExprParser.expr()
. - exitLogicalOpExpr(ExprParser.LogicalOpExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitLongArray(ExprParser.LongArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
longArray
labeled alternative inExprParser.expr()
. - exitLongArray(ExprParser.LongArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
longArray
labeled alternative inExprParser.expr()
. - exitLongArray(ExprParser.LongArrayContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitLongElement(ExprParser.LongElementContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by
ExprParser.longElement()
. - exitLongElement(ExprParser.LongElementContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by
ExprParser.longElement()
. - exitLongExpr(ExprParser.LongExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
longExpr
labeled alternative inExprParser.expr()
. - exitLongExpr(ExprParser.LongExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
longExpr
labeled alternative inExprParser.expr()
. - exitLongExpr(ExprParser.LongExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitMulDivModuloExpr(ExprParser.MulDivModuloExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
mulDivModuloExpr
labeled alternative inExprParser.expr()
. - exitMulDivModuloExpr(ExprParser.MulDivModuloExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
mulDivModuloExpr
labeled alternative inExprParser.expr()
. - exitMulDivModuloExpr(ExprParser.MulDivModuloExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitNestedExpr(ExprParser.NestedExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
nestedExpr
labeled alternative inExprParser.expr()
. - exitNestedExpr(ExprParser.NestedExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
nestedExpr
labeled alternative inExprParser.expr()
. - exitNestedExpr(ExprParser.NestedExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitNull(ExprParser.NullContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
null
labeled alternative inExprParser.expr()
. - exitNull(ExprParser.NullContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
null
labeled alternative inExprParser.expr()
. - exitNull(ExprParser.NullContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitNumericElement(ExprParser.NumericElementContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by
ExprParser.numericElement()
. - exitNumericElement(ExprParser.NumericElementContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by
ExprParser.numericElement()
. - exitPowOpExpr(ExprParser.PowOpExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
powOpExpr
labeled alternative inExprParser.expr()
. - exitPowOpExpr(ExprParser.PowOpExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
powOpExpr
labeled alternative inExprParser.expr()
. - exitPowOpExpr(ExprParser.PowOpExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.AddSubExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ApplyFunctionExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.DoubleArrayContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.DoubleExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitArrayContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitLongArrayContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitStringArrayContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.FunctionArgsContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.FunctionExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.IdentifierExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LambdaContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LiteralElementContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LogicalAndOrExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LogicalOpExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongArrayContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongElementContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.MulDivModuloExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.NestedExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.NullContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.NumericElementContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.PowOpExprContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StartContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringArrayContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringElementContext
- exitRule(ParseTreeListener) - Method in class org.apache.druid.math.expr.antlr.ExprParser.UnaryOpExprContext
- exitStart() - Method in class org.apache.druid.concurrent.LifecycleLock
-
Must be called before exit from start() on the lifecycled object, usually in a finally block.
- exitStart(ExprParser.StartContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by
ExprParser.start()
. - exitStart(ExprParser.StartContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by
ExprParser.start()
. - exitStop() - Method in class org.apache.druid.concurrent.LifecycleLock
-
Finalizes stopping the LifecycleLock.
- exitStopAndReset() - Method in class org.apache.druid.concurrent.LifecycleLock
-
Finalizes stopping the LifecycleLock and resets it, so that
LifecycleLock.canStart()
could be called again. - exitString(ExprParser.StringContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
string
labeled alternative inExprParser.expr()
. - exitString(ExprParser.StringContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
string
labeled alternative inExprParser.expr()
. - exitString(ExprParser.StringContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitStringArray(ExprParser.StringArrayContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
stringArray
labeled alternative inExprParser.expr()
. - exitStringArray(ExprParser.StringArrayContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
stringArray
labeled alternative inExprParser.expr()
. - exitStringArray(ExprParser.StringArrayContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exitStringElement(ExprParser.StringElementContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by
ExprParser.stringElement()
. - exitStringElement(ExprParser.StringElementContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by
ExprParser.stringElement()
. - exitUnaryOpExpr(ExprParser.UnaryOpExprContext) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
-
Exit a parse tree produced by the
unaryOpExpr
labeled alternative inExprParser.expr()
. - exitUnaryOpExpr(ExprParser.UnaryOpExprContext) - Method in interface org.apache.druid.math.expr.antlr.ExprListener
-
Exit a parse tree produced by the
unaryOpExpr
labeled alternative inExprParser.expr()
. - exitUnaryOpExpr(ExprParser.UnaryOpExprContext) - Method in class org.apache.druid.math.expr.ExprListenerImpl
- exp(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Exp() - Constructor for class org.apache.druid.math.expr.Function.Exp
- EXP - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- EXP - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- expectAppendable(RowsAndColumns) - Static method in interface org.apache.druid.query.rowsandcols.RowsAndColumns
- EXPECTED_VERSION - Static variable in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexMetricSerde
- EXPECTED_VERSION - Static variable in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexMetricSerde
- EXPECTED_VERSION - Static variable in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexMetricSerde
- EXPECTED_VERSION - Static variable in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexMetricSerde
- ExplicitArrayContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.ExplicitArrayContext
- ExplicitLongArrayContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.ExplicitLongArrayContext
- ExplicitStringArrayContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.ExplicitStringArrayContext
- ExplodingSequence<T> - Class in org.apache.druid.java.util.common.guava
-
Wraps an underlying sequence and allows us to force it to explode at various points.
- ExplodingSequence(Sequence<T>, boolean, boolean) - Constructor for class org.apache.druid.java.util.common.guava.ExplodingSequence
- expm1(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Expm1() - Constructor for class org.apache.druid.math.expr.Function.Expm1
- ExportStorageProvider - Interface in org.apache.druid.storage
- exportTable(String, String) - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.AddSubExprContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.FunctionArgsContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LambdaContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LogicalAndOrExprContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LogicalOpExprContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.MulDivModuloExprContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.NestedExprContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.PowOpExprContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.StartContext
- expr() - Method in class org.apache.druid.math.expr.antlr.ExprParser.UnaryOpExprContext
- expr(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.AddSubExprContext
- expr(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.FunctionArgsContext
- expr(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LogicalAndOrExprContext
- expr(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LogicalOpExprContext
- expr(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.MulDivModuloExprContext
- expr(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.PowOpExprContext
- Expr - Interface in org.apache.druid.math.expr
-
Base interface of Druid expression language abstract syntax tree nodes.
- EXPR_CACHE_KEY - Static variable in class org.apache.druid.math.expr.Exprs
- EXPR_MACROS - Static variable in class org.apache.druid.guice.ExpressionModule
- Expr.BindingAnalysis - Class in org.apache.druid.math.expr
-
Information about the context in which
IdentifierExpr
are used in a greaterExpr
, listing the 'free variables' (total set of required input columns or values) and distinguishing between which identifiers are used as scalar inputs and which are used as array inputs. - Expr.InputBindingInspector - Interface in org.apache.druid.math.expr
-
Mechanism to supply input types for the bindings which will back
IdentifierExpr
, to use in the aid of inferring the output type of an expression withExpr.getOutputType(org.apache.druid.math.expr.Expr.InputBindingInspector)
. - Expr.ObjectBinding - Interface in org.apache.druid.math.expr
-
Mechanism to supply values to back
IdentifierExpr
during expression evaluation - Expr.Shuttle - Interface in org.apache.druid.math.expr
-
Mechanism to rewrite an
Expr
, implementing aExpr.Shuttle
allows visiting all children of anExpr
, and replacing them as desired. - Expr.VectorInputBinding - Interface in org.apache.druid.math.expr
-
Mechanism to supply batches of input values to a
ExprVectorProcessor
for optimized processing. - Expr.VectorInputBindingInspector - Interface in org.apache.druid.math.expr
-
Expr.InputBindingInspector
+ vectorizations stuff forExpr.asVectorProcessor(org.apache.druid.math.expr.Expr.VectorInputBindingInspector)
- ExprBaseListener - Class in org.apache.druid.math.expr.antlr
-
This class provides an empty implementation of
ExprListener
, which can be extended to create a listener which only needs to handle a subset of the available methods. - ExprBaseListener() - Constructor for class org.apache.druid.math.expr.antlr.ExprBaseListener
- ExprContext() - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.ExprContext
- ExprContext(ParserRuleContext, int) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.ExprContext
- 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
- EXPRESSION - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- EXPRESSION_LAMBDA_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- ExpressionColumnValueSelector - Class in org.apache.druid.segment.virtual
-
Basic expression
ColumnValueSelector
. - ExpressionColumnValueSelector(Expr, Expr.ObjectBinding, RowIdSupplier) - Constructor for class org.apache.druid.segment.virtual.ExpressionColumnValueSelector
- ExpressionDimFilter - Class in org.apache.druid.query.filter
- ExpressionDimFilter(String, ExprMacroTable) - Constructor for class org.apache.druid.query.filter.ExpressionDimFilter
-
Constructor used in various tests that don't need to provide
FilterTuning
. - ExpressionDimFilter(String, Expr, FilterTuning) - Constructor for class org.apache.druid.query.filter.ExpressionDimFilter
-
Constructor for already-parsed-and-analyzed expressions.
- ExpressionDimFilter(String, FilterTuning, ExprMacroTable) - Constructor for class org.apache.druid.query.filter.ExpressionDimFilter
-
Constructor for deserialization.
- ExpressionFilter - Class in org.apache.druid.segment.filter
- ExpressionFilter(Supplier<Expr>, FilterTuning) - Constructor for class org.apache.druid.segment.filter.ExpressionFilter
- ExpressionLambdaAggregator - Class in org.apache.druid.query.aggregation
- ExpressionLambdaAggregator(ExpressionLambdaAggregatorFactory.FactorizePlan, int) - Constructor for class org.apache.druid.query.aggregation.ExpressionLambdaAggregator
- ExpressionLambdaAggregatorFactory - Class in org.apache.druid.query.aggregation
- ExpressionLambdaAggregatorFactory(String, Set<String>, String, String, String, Boolean, Boolean, Boolean, String, String, String, String, HumanReadableBytes, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- ExpressionLambdaAggregatorFactory.FactorizePlan - Class in org.apache.druid.query.aggregation
-
Determine how to factorize the aggregator
- ExpressionLambdaAggregatorInputBindings - Class in org.apache.druid.query.aggregation
-
Special
Expr.ObjectBinding
for use withExpressionLambdaAggregatorFactory
. - ExpressionLambdaAggregatorInputBindings(Expr.ObjectBinding, String, ExprEval<?>) - Constructor for class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorInputBindings
- ExpressionLambdaBufferAggregator - Class in org.apache.druid.query.aggregation
- ExpressionLambdaBufferAggregator(ExpressionLambdaAggregatorFactory.FactorizePlan, int) - Constructor for class org.apache.druid.query.aggregation.ExpressionLambdaBufferAggregator
- ExpressionModule - Class in org.apache.druid.guice
-
Module that binds
ExprMacroTable
toGuiceExprMacroTable
and configures a starter set ofExprMacroTable.ExprMacro
for all macros defined in the "druid-processing" module. - ExpressionModule() - Constructor for class org.apache.druid.guice.ExpressionModule
- ExpressionMultiValueDimensionSelector - Class in org.apache.druid.segment.virtual
-
Basic multi-value dimension selector for an
Expr
evaluatingColumnValueSelector
. - 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, ColumnType, Expr) - Constructor for class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
-
Constructor for a pre-parsed expression.
- ExpressionPostAggregator(String, String, String, ColumnType, ExprMacroTable) - Constructor for class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
-
Constructor for deserialization.
- ExpressionPostAggregator.Ordering - Enum in org.apache.druid.query.aggregation.post
- ExpressionPredicateIndexSupplier - Class in org.apache.druid.math.expr
- ExpressionPredicateIndexSupplier(Expr, String, ExpressionType, ColumnType, DictionaryEncodedValueIndex<?>) - Constructor for class org.apache.druid.math.expr.ExpressionPredicateIndexSupplier
- ExpressionProcessing - Class in org.apache.druid.math.expr
-
Like
NullHandling
, except for expressions processing configs - ExpressionProcessing() - Constructor for class org.apache.druid.math.expr.ExpressionProcessing
- ExpressionProcessingConfig - Class in org.apache.druid.math.expr
- ExpressionProcessingConfig(Boolean, Boolean, Boolean) - Constructor for class org.apache.druid.math.expr.ExpressionProcessingConfig
- ExpressionProcessingException - Exception in org.apache.druid.math.expr
- ExpressionProcessingException(NamedFunction, String, Object...) - Constructor for exception org.apache.druid.math.expr.ExpressionProcessingException
- ExpressionProcessingException(NamedFunction, Throwable, String, Object...) - Constructor for exception org.apache.druid.math.expr.ExpressionProcessingException
- ExpressionProcessingModule - Class in org.apache.druid.math.expr
- ExpressionProcessingModule() - Constructor for class org.apache.druid.math.expr.ExpressionProcessingModule
- 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
- ExpressionType - Class in org.apache.druid.math.expr
-
The type system used to process Druid expressions.
- ExpressionType(ExprType, String, ExpressionType) - Constructor for class org.apache.druid.math.expr.ExpressionType
- ExpressionTypeConversion - Class in org.apache.druid.math.expr
- ExpressionTypeFactory - Class in org.apache.druid.math.expr
- ExpressionValidationException - Exception in org.apache.druid.math.expr
- ExpressionValidationException(NamedFunction, String, Object...) - Constructor for exception org.apache.druid.math.expr.ExpressionValidationException
- ExpressionValidationException(NamedFunction, Throwable, String, Object...) - Constructor for exception org.apache.druid.math.expr.ExpressionValidationException
- ExpressionVectorInputBinding - Class in org.apache.druid.segment.virtual
- ExpressionVectorInputBinding(ReadableVectorInspector) - Constructor for class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- 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, Expr, ColumnType) - Constructor for class org.apache.druid.segment.virtual.ExpressionVirtualColumn
-
Constructor for creating an ExpressionVirtualColumn from a pre-parsed-and-analyzed expression, where the original expression string is known.
- ExpressionVirtualColumn(String, String, ColumnType, ExprMacroTable) - Constructor for class org.apache.druid.segment.virtual.ExpressionVirtualColumn
-
Constructor for deserialization.
- ExpressionVirtualColumn(String, Expr, ColumnType) - Constructor for class org.apache.druid.segment.virtual.ExpressionVirtualColumn
-
Constructor for creating an ExpressionVirtualColumn from a pre-parsed expression, where the original expression string is not known.
- ExprEval<T> - Class in org.apache.druid.math.expr
- ExprEvalDoubleVector - Class in org.apache.druid.math.expr.vector
- ExprEvalDoubleVector(double[], boolean[]) - Constructor for class org.apache.druid.math.expr.vector.ExprEvalDoubleVector
- ExprEvalLongVector - Class in org.apache.druid.math.expr.vector
- ExprEvalLongVector(long[], boolean[]) - Constructor for class org.apache.druid.math.expr.vector.ExprEvalLongVector
- ExprEvalObjectVector - Class in org.apache.druid.math.expr.vector
- ExprEvalObjectVector(Object[]) - Constructor for class org.apache.druid.math.expr.vector.ExprEvalObjectVector
- ExprEvalVector<T> - Class in org.apache.druid.math.expr.vector
-
Result of
ExprVectorProcessor.evalVector(org.apache.druid.math.expr.Expr.VectorInputBinding)
which wraps the actual evaluated results of the operation over the input vector(s). - ExprEvalVector(T, boolean[]) - Constructor for class org.apache.druid.math.expr.vector.ExprEvalVector
- ExprLexer - Class in org.apache.druid.math.expr.antlr
- ExprLexer(CharStream) - Constructor for class org.apache.druid.math.expr.antlr.ExprLexer
- ExprListener - Interface in org.apache.druid.math.expr.antlr
-
This interface defines a complete listener for a parse tree produced by
ExprParser
. - ExprListenerImpl - Class in org.apache.druid.math.expr
- ExprMacroTable - Class in org.apache.druid.math.expr
-
Mechanism by which Druid expressions can define new functions for the Druid expression language.
- ExprMacroTable(List<ExprMacroTable.ExprMacro>) - Constructor for class org.apache.druid.math.expr.ExprMacroTable
- ExprMacroTable.BaseMacroFunctionExpr - Class in org.apache.druid.math.expr
-
Base class for
Expr
fromExprMacroTable.ExprMacro
. - ExprMacroTable.BaseScalarMacroFunctionExpr - Class in org.apache.druid.math.expr
-
Base class for
Expr
fromExprMacroTable.ExprMacro
that accepts all-scalar arguments. - ExprMacroTable.ExprMacro - Interface in org.apache.druid.math.expr
- ExprMacroTable.ExprMacroFunctionExpr - Interface in org.apache.druid.math.expr
-
stub interface to allow
Parser.flatten(Expr)
a way to recognize macro functions that exend this - ExprParser - Class in org.apache.druid.math.expr.antlr
- ExprParser(TokenStream) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser
- ExprParser.AddSubExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.ApplyFunctionExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.DoubleArrayContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.DoubleExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.ExplicitArrayContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.ExplicitLongArrayContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.ExplicitStringArrayContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.ExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.FnArgsContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.FunctionArgsContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.FunctionExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.IdentifierExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.LambdaContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.LiteralElementContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.LogicalAndOrExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.LogicalOpExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.LongArrayContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.LongElementContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.LongExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.MulDivModuloExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.NestedExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.NullContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.NumericElementContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.PowOpExprContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.StartContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.StringArrayContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.StringContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.StringElementContext - Class in org.apache.druid.math.expr.antlr
- ExprParser.UnaryOpExprContext - Class in org.apache.druid.math.expr.antlr
- Exprs - Class in org.apache.druid.math.expr
- Exprs() - Constructor for class org.apache.druid.math.expr.Exprs
- ExprType - Enum in org.apache.druid.math.expr
-
Base 'value' types of Druid expression language, all
Expr
must evaluate to one of these types. - ExprUtils - Class in org.apache.druid.query.expression
- ExprUtils() - Constructor for class org.apache.druid.query.expression.ExprUtils
- ExprVectorProcessor<TOutput> - Interface in org.apache.druid.math.expr.vector
-
Interface describing vectorized expression processors, which can be specialized using input type information to produce optimized expression evaluators, which can operate on batches of primitive data with minimal object overhead
- ExtensionFirstClassLoader - Class in org.apache.druid.guice
-
The ClassLoader that gets used when druid.extensions.useExtensionClassloaderFirst = true.
- ExtensionFirstClassLoader(URL[], ClassLoader) - Constructor for class org.apache.druid.guice.ExtensionFirstClassLoader
- ExtensionPoint - Annotation Type in org.apache.druid.guice.annotations
-
Signifies that the annotated type is an extension point.
- ExtensionsConfig - Class in org.apache.druid.guice
- ExtensionsConfig() - Constructor for class org.apache.druid.guice.ExtensionsConfig
- ExtensionsLoader - Class in org.apache.druid.guice
-
Manages the loading of Druid extensions.
- ExtensionsLoader(ExtensionsConfig) - Constructor for class org.apache.druid.guice.ExtensionsLoader
- ExtensionsModule - Class in org.apache.druid.guice
-
Module for the extensions loader.
- ExtensionsModule() - Constructor for class org.apache.druid.guice.ExtensionsModule
- ExtensionsModule.SecondaryModule - Class in org.apache.druid.guice
-
Transfers the now-populated extension loader instance from the startup to the main injector.
- extraConfigAndSetObjectMap(Map<String, Object>, String, ObjectMapper) - Static method in class org.apache.druid.utils.DynamicConfigProviderUtils
- extraConfigAndSetStringMap(Map<String, Object>, String, ObjectMapper) - Static method in class org.apache.druid.utils.DynamicConfigProviderUtils
- 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, ExtractionFn) - Constructor for class org.apache.druid.query.dimension.ExtractionDimensionSpec
- ExtractionDimensionSpec(String, String, ColumnType, ExtractionFn) - Constructor for class org.apache.druid.query.dimension.ExtractionDimensionSpec
- ExtractionDimensionSpec(String, String, ColumnType, ExtractionFn, 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 - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
- 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.ExtractionType - Enum in org.apache.druid.query.extraction
- extractKeys(List<String>, long, InputRow) - Static method in class org.apache.druid.timeline.partition.HashPartitioner
- extractTimestamp(Map<String, Object>) - Method in class org.apache.druid.data.input.impl.TimestampSpec
- 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() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerdeFactory
-
Create a new
Grouper.KeySerde
, which may be stateful. - 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.ExpressionLambdaAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.mean.DoubleMeanAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SingleValueAggregatorFactory
- factorize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- 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, 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(DataSegment, File, boolean, SegmentLazyLoadFailCallback) - Method in class org.apache.druid.segment.loading.BroadcastJoinableMMappedQueryableSegmentizerFactory
- factorize(DataSegment, File, boolean, SegmentLazyLoadFailCallback) - Method in class org.apache.druid.segment.loading.MMappedQueryableSegmentizerFactory
- factorize(DataSegment, File, boolean, SegmentLazyLoadFailCallback) - Method in interface org.apache.druid.segment.loading.SegmentizerFactory
- factorize(DataSegment, File, boolean, SegmentLazyLoadFailCallback) - Method in class org.apache.druid.segment.loading.TombstoneSegmentizerFactory
- 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.ExpressionLambdaAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.mean.DoubleMeanAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SingleValueAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- factorizeBuffered(ColumnSelectorFactory, List<AggregatorFactory>) - Static method in class org.apache.druid.query.aggregation.AggregatorAdapters
-
Create an adapters object based on
BufferAggregator
. - 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, T) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
-
Creates an
BufferAggregator
to aggregate values from several rows into a ByteBuffer. - 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.cardinality.CardinalityAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- factorizeVector(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
- 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) - 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, 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, 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, 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, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
-
Creates a
VectorAggregator
to aggregate values from several rows into a ByteBuffer. - factorizeWithDictionary(List<String>) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerdeFactory
-
Create a new
Grouper.KeySerde
with the given dictionary. - factorizeWithSize(ColumnSelectorFactory) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Creates an
Aggregator
based on the provided column selector factory. - fail(Throwable) - Method in class org.apache.druid.frame.channel.ComposingWritableFrameChannel
- fail(Throwable) - Method in interface org.apache.druid.frame.channel.WritableFrameChannel
-
Called prior to
WritableFrameChannel.close()
if the writer has failed. - fail(Throwable) - Method in class org.apache.druid.frame.channel.WritableFrameFileChannel
- FAILED - org.apache.druid.indexer.TaskState
- failure(Exception) - Static method in class org.apache.druid.common.config.ConfigManager.SetResult
- failure(String, String) - Static method in class org.apache.druid.indexer.TaskStatus
-
All failed task status must have a non-null error message.
- Failure(String) - Constructor for class org.apache.druid.error.DruidException.Failure
- FallbackPredicate<T> - Class in org.apache.druid.query.filter
-
Predicate
that wraps another predicate and can catchClassCastException
from someComparator
and degrades into casting input to an expectedExpressionType
once an exception is encountered. - FallbackPredicate(DruidObjectPredicate<T>, ExpressionType) - Constructor for class org.apache.druid.query.filter.FallbackPredicate
- FallbackVirtualColumn - Class in org.apache.druid.segment.virtual
-
A virtual column that picks one column or another based on whether they exist.
- FallbackVirtualColumn(String, ArrayList<DimensionSpec>) - Constructor for class org.apache.druid.segment.virtual.FallbackVirtualColumn
- FALSE - org.apache.druid.query.filter.DruidPredicateMatch
-
Value does not match
- FALSE - org.apache.druid.query.QueryContexts.Vectorize
- FALSE - org.apache.druid.segment.column.ColumnCapabilities.Capable
- FalseDimFilter - Class in org.apache.druid.query.filter
- FalseFilter - Class in org.apache.druid.segment.filter
- FastJacksonJsonNodeJsonProvider - Class in org.apache.druid.data.input.impl
-
Custom json-path JsonProvider override to circumvent slow performance when encountering null paths as described in https://github.com/json-path/JsonPath/issues/396 Note that this only avoids errors for map properties, avoiding the exception on array paths is not possible without patching json-path itself
- FastJacksonJsonNodeJsonProvider() - Constructor for class org.apache.druid.data.input.impl.FastJacksonJsonNodeJsonProvider
- FastLineIterator<T> - Class in org.apache.druid.data.input.impl
-
Like the Apache Commons LineIterator, but faster.
- FastLineIterator(InputStream) - Constructor for class org.apache.druid.data.input.impl.FastLineIterator
-
Constructor; a local buffer will be created
- FastLineIterator(InputStream, byte[]) - Constructor for class org.apache.druid.data.input.impl.FastLineIterator
-
Constructor; BYO buffer.
- FastLineIterator.Bytes - Class in org.apache.druid.data.input.impl
- FastLineIterator.Strings - Class in org.apache.druid.data.input.impl
- fastLooseChop(String, int) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Shorten "s" to "maxBytes" chars.
- feed - Variable in class org.apache.druid.java.util.metrics.FeedDefiningMonitor
- FEED - Static variable in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- FeedDefiningMonitor - Class in org.apache.druid.java.util.metrics
- FeedDefiningMonitor(String) - Constructor for class org.apache.druid.java.util.metrics.FeedDefiningMonitor
- FeedUriExtractor - Class in org.apache.druid.java.util.emitter.core
- FeedUriExtractor(String) - Constructor for class org.apache.druid.java.util.emitter.core.FeedUriExtractor
- fetch(File, byte[]) - Method in class org.apache.druid.data.input.BytesCountingInputEntity
- fetch(File, byte[]) - Method in class org.apache.druid.data.input.impl.FileEntity
- fetch(File, byte[]) - Method in interface org.apache.druid.data.input.InputEntity
-
Fetches the input entity into the local storage.
- fetch(QueryResourceId) - Method in class org.apache.druid.query.groupby.GroupByResourcesReservationPool
-
Fetches resources corresponding to the given resource id
- 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)
. - fetchAuditHistory(String, int) - Method in interface org.apache.druid.audit.AuditManager
-
Provides last N entries of audit history for given type
- fetchAuditHistory(String, String, int) - Method in interface org.apache.druid.audit.AuditManager
-
Provides last N entries of audit history for given key, type
- fetchAuditHistory(String, String, Interval) - Method in interface org.apache.druid.audit.AuditManager
-
Fetches audit entries made for the given key, type and interval.
- fetchAuditHistory(String, Interval) - Method in interface org.apache.druid.audit.AuditManager
-
Fetches audit entries of a type whose audit time lies in the given interval.
- 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
- fieldCount() - Method in class org.apache.druid.frame.field.RowReader
- FieldDimensionSelector(ColumnValueSelector<?>) - Constructor for class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.FieldDimensionSelector
- fieldEndPosition(byte[], int) - Static method in class org.apache.druid.frame.key.RowKeyReader
- 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
- fieldIndexers - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
- fieldIndexers - Variable in class org.apache.druid.segment.NestedDataColumnIndexerV4
- 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
- fieldName - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- fieldReader(int) - Method in class org.apache.druid.frame.field.RowReader
- FieldReader - Interface in org.apache.druid.frame.field
-
Embeds the logic to read a specific field from row-based frames or from
RowKey
. - FieldReaders - Class in org.apache.druid.frame.field
-
Helper used to read field values from row-based frames or
RowKey
. - fieldResourceCloser - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- fieldsToString() - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- FieldTypeInfo - Class in org.apache.druid.segment.nested
-
Binary serialization for nested field type info, translated into this compact format for storage in segments.
- FieldTypeInfo(ByteBuffer) - Constructor for class org.apache.druid.segment.nested.FieldTypeInfo
- FieldTypeInfo.MutableTypeSet - Class in org.apache.druid.segment.nested
- FieldTypeInfo.TypeSet - Class in org.apache.druid.segment.nested
- FieldTypeInfo.Writer - Class in org.apache.druid.segment.nested
- FieldWriter - Interface in org.apache.druid.frame.field
-
Helper used to write field values to row-based frames or
RowKey
. - FieldWriters - Class in org.apache.druid.frame.field
-
Helper used to write field values to row-based frames or
RowKey
. - FIFTEEN_MINUTE - org.apache.druid.java.util.common.granularity.GranularityType
- FIFTEEN_MINUTE - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- file() - Method in interface org.apache.druid.data.input.InputEntity.CleanableFile
- file() - Method in class org.apache.druid.frame.file.FrameFile
-
Returns the file that this instance is backed by.
- FileCopyResult(File...) - Constructor for class org.apache.druid.java.util.common.FileUtils.FileCopyResult
- FileCopyResult(Collection<File>) - Constructor for class org.apache.druid.java.util.common.FileUtils.FileCopyResult
- FileEntity - Class in org.apache.druid.data.input.impl
- FileEntity(File) - Constructor for class org.apache.druid.data.input.impl.FileEntity
- FileOutputChannelFactory - Class in org.apache.druid.frame.processor
- FileOutputChannelFactory(File, int, ByteTracker) - Constructor for class org.apache.druid.frame.processor.FileOutputChannelFactory
- FilePerSplitHintSpec - Class in org.apache.druid.data.input
-
Assigns each input file to its own split.
- FileSmoosher - Class in org.apache.druid.java.util.common.io.smoosh
-
A class that concatenates files together into configurable sized chunks, works in conjunction with the SmooshedFileMapper to provide access to the individual files.
- FileSmoosher(File) - Constructor for class org.apache.druid.java.util.common.io.smoosh.FileSmoosher
- FileSmoosher(File, int) - Constructor for class org.apache.druid.java.util.common.io.smoosh.FileSmoosher
- FileSmoosher.Outer - Class in org.apache.druid.java.util.common.io.smoosh
- FileUtils - Class in org.apache.druid.java.util.common
- FileUtils() - Constructor for class org.apache.druid.java.util.common.FileUtils
- FileUtils.FileCopyResult - Class in org.apache.druid.java.util.common
-
Keeps results of a file copy, including children and total size of the resultant files.
- FileUtils.InputStreamSupplier - Interface in org.apache.druid.java.util.common
-
Like
ByteSource
, but this is an interface, which allows use of lambdas. - FileUtils.LinkOrCopyResult - Enum in org.apache.druid.java.util.common
- FileUtils.OutputStreamConsumer<T> - Interface in org.apache.druid.java.util.common
- fill(byte) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- fill(byte) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- fill(int, int) - Method in class org.apache.druid.collections.fastutil.DruidIntList
- fill(long, long, byte) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- fillBitmapsFromUnsortedEncodedKeyComponent(int[], int, MutableBitmap[], BitmapFactory) - Method in class org.apache.druid.segment.StringDimensionIndexer
- 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(StructuredData, int, MutableBitmap[], BitmapFactory) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- fillBitmapsFromUnsortedEncodedKeyComponent(StructuredData, int, MutableBitmap[], BitmapFactory) - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- fillRuns(int[], int, int) - Method in class org.apache.druid.collections.fastutil.DruidIntList
- fillWithRepeat(int[], int) - Method in class org.apache.druid.collections.fastutil.DruidIntList
- filter - Variable in class org.apache.druid.query.search.CursorOnlyStrategy.CursorBasedExecutor
- filter - Variable in class org.apache.druid.query.search.SearchStrategy
- filter(Predicate<? super T>) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- filter(Predicate<T>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- filter(Predicate<T>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- filter(Iterable<ImmutableFloatPoint>) - Method in class org.apache.druid.collections.spatial.search.PolygonBound
- filter(Iterable<ImmutableFloatPoint>) - Method in class org.apache.druid.collections.spatial.search.RadiusBound
- filter(Iterable<ImmutableFloatPoint>) - Method in class org.apache.druid.collections.spatial.search.RectangularBound
- filter(Iterable<TPoint>) - Method in interface org.apache.druid.collections.spatial.search.Bound
- filter(Sequence<T>, Predicate<? super T>) - Static method in class org.apache.druid.java.util.common.guava.Sequences
- Filter - Interface in org.apache.druid.query.filter
- filterAllowList(Set<String>, DimensionSelector, boolean) - Static method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
- filterBundle(FilterBundle.BundleInfo) - Method in interface org.apache.druid.query.QueryMetrics
- filterBundle(FilterBundle.BundleInfo) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- FilterBundle - Class in org.apache.druid.query.filter
-
FilterBundle is a container for all the goodies used for producing filtered cursors, a
ImmutableBitmap
if the filter can use an index, and/or aFilterBundle.MatcherBundle
which contains functions to buildValueMatcher
andVectorValueMatcher
for any filters which must be evaluated row by row during the cursor scan. - FilterBundle(FilterBundle.IndexBundle, FilterBundle.MatcherBundle) - Constructor for class org.apache.druid.query.filter.FilterBundle
- FilterBundle.BundleInfo - Class in org.apache.druid.query.filter
- FilterBundle.IndexBundle - Interface in org.apache.druid.query.filter
- FilterBundle.IndexBundleInfo - Class in org.apache.druid.query.filter
- FilterBundle.MatcherBundle - Interface in org.apache.druid.query.filter
-
Builder of
ValueMatcher
andVectorValueMatcher
. - FilterBundle.MatcherBundleInfo - Class in org.apache.druid.query.filter
- FilterBundle.SimpleIndexBundle - Class in org.apache.druid.query.filter
- FilterBundle.SimpleMatcherBundle - Class in org.apache.druid.query.filter
- 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
- filterDenyList(Set<String>, DimensionSelector, boolean) - Static method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
- 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
- FilteredDataSource - Class in org.apache.druid.query
-
This class models a data source to be unnested which is present along with a filter.
- FilteredOffset - Class in org.apache.druid.segment
- FilteredSequence<T> - Class in org.apache.druid.java.util.common.guava
- FilteredSequence(Sequence<T>, Predicate<? super T>) - Constructor for class org.apache.druid.java.util.common.guava.FilteredSequence
- FilteredStorageAdapter - Class in org.apache.druid.segment
- FilteredStorageAdapter(StorageAdapter, DimFilter) - Constructor for class org.apache.druid.segment.FilteredStorageAdapter
- 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
- FilterFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.FilterFunction
- FilteringAccumulator<OutType,T> - Class in org.apache.druid.java.util.common.guava
- FilteringAccumulator(Predicate<? super T>, Accumulator<OutType, T>) - Constructor for class org.apache.druid.java.util.common.guava.FilteringAccumulator
- FilteringYieldingAccumulator<OutType,T> - Class in org.apache.druid.java.util.common.guava
- FilteringYieldingAccumulator(Predicate<? super T>, YieldingAccumulator<OutType, T>) - Constructor for class org.apache.druid.java.util.common.guava.FilteringYieldingAccumulator
- 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(String, String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- filters(String, String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
- filters(String, String) - 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.Druids.TimeseriesQueryBuilder
- filters(String, String, String...) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- filters(DimFilter) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- filters(DimFilter) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- filters(DimFilter) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
- filters(DimFilter) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- 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(TimeBoundaryQuery, List<T>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
- 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.
- filterShards(DimFilter, Set<String>, 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 - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
- FilterTuning - Class in org.apache.druid.query.filter
-
This class provides a mechanism to influence whether or not indexes are used for a
Filter
during processing byFilter.makeFilterBundle(ColumnIndexSelector, BitmapResultFactory, int, int, boolean)
(i.e. - FilterTuning(Boolean, Integer, Integer) - Constructor for class org.apache.druid.query.filter.FilterTuning
- finalize() - Method in class org.apache.druid.java.util.emitter.EmittingLogger.EmittingAlertBuilder
- 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.JavaScriptAggregatorFactory
- 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.ExpressionLambdaAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
- finalizeComputation(Object) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- finalizeConversionForMap(Object) - Method in class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- finalizeConversionForMap(Object) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
-
Handle any special conversions for object when translating an input type into a
Map
forObjectFlatteners.FlattenerMaker.toMap(T)
- 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 corresponding to "key" in this index.
- find(Object) - Method in class org.apache.druid.segment.join.table.MapIndex
- find(Object) - Method in class org.apache.druid.segment.join.table.UniqueLongArrayIndex
- find(Object) - Method in class org.apache.druid.segment.nested.NestedPathArrayElement
- find(Object) - Method in class org.apache.druid.segment.nested.NestedPathField
- find(Object) - Method in interface org.apache.druid.segment.nested.NestedPathPart
- find(Object, List<NestedPathPart>) - Static method in class org.apache.druid.segment.nested.NestedPathFinder
-
Dig through a thing to find stuff
- find(String) - Method in class org.apache.druid.query.context.ResponseContext.Keys
-
Returns a registered key associated with the given name, or
null
if the key is not registered. - 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.
- findChunk(Interval, VersionType, int) - Method in interface org.apache.druid.timeline.TimelineLookup
-
Finds the
PartitionChunk
for the given time interval, version and chunk number. - findChunk(Interval, VersionType, int) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.AppendableMapOfColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.ConcatRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.concrete.ColumnBasedFrameRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.concrete.QueryableIndexRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.concrete.RowBasedFrameRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.EmptyRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.LazilyDecoratedRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.LimitedRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.RearrangedRowsAndColumns
- findColumn(String) - Method in interface org.apache.druid.query.rowsandcols.RowsAndColumns
-
Finds a column by name.
- findColumn(String) - Method in class org.apache.druid.query.rowsandcols.StorageAdapterRowsAndColumns
- findComplex(int, int, Object) - Method in interface org.apache.druid.query.rowsandcols.column.BinarySearchableAccessor
- findComplex(int, int, Object) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- findDimensions(TimestampSpec, DimensionsSpec, Set<String>) - Static method in class org.apache.druid.data.input.impl.MapInputRowParser
-
Finds the final set of dimension names to use for
InputRow
. - findDisallowedFieldNames(RowSignature) - Static method in class org.apache.druid.frame.write.FrameWriterUtils
-
Checks the provided signature for any disallowed field names.
- findDouble(int, int, double) - Method in interface org.apache.druid.query.rowsandcols.column.BinarySearchableAccessor
- findDouble(int, int, double) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- findFactory(QueryType) - Method in class org.apache.druid.query.DefaultQueryRunnerFactoryConglomerate
- findFactory(QueryType) - Method in interface org.apache.druid.query.QueryRunnerFactoryConglomerate
- findFloat(int, int, float) - Method in interface org.apache.druid.query.rowsandcols.column.BinarySearchableAccessor
- findFloat(int, int, float) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- findFullyOvershadowed() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
-
This method should be deduplicated with DataSourcesSnapshot.determineOvershadowedSegments(): see https://github.com/apache/druid/issues/8070.
- findInjectableValue(AnnotatedMember) - Method in class org.apache.druid.guice.GuiceAnnotationIntrospector
- findInjectableValue(Object, DeserializationContext, BeanProperty, Object) - Method in class org.apache.druid.guice.GuiceInjectableValues
- findKeys(Object, List<NestedPathPart>) - Static method in class org.apache.druid.segment.nested.NestedPathFinder
-
find the list of 'keys' at some path.
- findLong(int, int, long) - Method in interface org.apache.druid.query.rowsandcols.column.BinarySearchableAccessor
- findLong(int, int, long) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- findMonitor(Class<T>) - Method in class org.apache.druid.java.util.metrics.MonitorScheduler
-
Returns a
Monitor
instance of the given class if any. - findNonOvershadowedObjectsInInterval(Interval, Partitions) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
-
Computes a set with all objects falling within the specified interval which are at least partially "visible" in this interval (that is, are not fully overshadowed within this interval).
- findNull(int, int) - Method in interface org.apache.druid.query.rowsandcols.column.BinarySearchableAccessor
- findNull(int, int) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- findNumComplexAggs(List<AggregatorFactory>) - Static method in class org.apache.druid.query.DruidMetrics
- findOpenPort(int) - Static method in class org.apache.druid.common.utils.SocketUtil
- findOpenPortFrom(int) - Static method in class org.apache.druid.common.utils.SocketUtil
- findOrCreateInputRowSignature(List<String>) - Static method in class org.apache.druid.data.input.TextReader
- findOverlappingInterval(Interval, Interval[]) - Static method in class org.apache.druid.java.util.common.Intervals
-
Finds an interval from the given set of sortedIntervals which overlaps with the searchInterval.
- findPropertyIgnorals(Annotated) - Method in class org.apache.druid.guice.GuiceAnnotationIntrospector
-
This method is used to find what property to ignore in deserialization.
- findReport(String) - Method in class org.apache.druid.indexer.report.TaskReport.ReportMap
- FindResult - Class in org.apache.druid.query.rowsandcols.util
- findRow(int, SortedMatrixMaker.SortedMatrix.MatrixRow) - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix
- findString(int, int, String) - Method in interface org.apache.druid.query.rowsandcols.column.BinarySearchableAccessor
- findString(int, int, String) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- findUniqueLong(long) - Method in interface org.apache.druid.segment.join.table.IndexedTable.Index
-
Returns the row number corresponding to "key" in this index, or
IndexedTable.Index.NOT_FOUND
if the key does not exist in the index. - findUniqueLong(long) - Method in class org.apache.druid.segment.join.table.MapIndex
- findUniqueLong(long) - Method in class org.apache.druid.segment.join.table.UniqueLongArrayIndex
- finish() - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
-
Signal that no more inputs are added.
- finished(T) - Static method in class org.apache.druid.java.util.http.client.response.ClientResponse
- finished(T, boolean) - Static method in class org.apache.druid.java.util.http.client.response.ClientResponse
- Firehose - Interface in org.apache.druid.data.input
-
Deprecated.
- FirehoseFactory<T extends InputRowParser> - Interface in org.apache.druid.data.input
-
Deprecated.
- first - Variable in class org.apache.druid.java.util.common.Triple
- first() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- FIRST_PREDICATE - Static variable in interface org.apache.druid.query.aggregation.firstlast.SelectionPredicate
- firstDictionaryValue - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- firstInt() - Method in class org.apache.druid.collections.RangeIntSet
- FirstLastUtils - Class in org.apache.druid.query.aggregation.firstlast
- FirstLastUtils() - Constructor for class org.apache.druid.query.aggregation.firstlast.FirstLastUtils
- FirstLastVectorAggregator<RhsType,PairType extends SerializablePair<Long,RhsType>> - Class in org.apache.druid.query.aggregation.firstlast
-
Base type for vectorized version of on heap 'last' aggregator for primitive numeric column selectors..
- FirstLastVectorAggregator(VectorValueSelector, VectorValueSelector, VectorObjectSelector, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
-
timeSelector can be null, however aggregate functions are no-op then.
- firstNonNull(T, T) - Static method in class org.apache.druid.common.guava.GuavaUtils
-
If first argument is not null, return it, else return the other argument.
- firstOrNull(StringTuple) - Static method in class org.apache.druid.data.input.StringTuple
-
Gets the first String from the given StringTuple if the tuple is non-null and non-empty, null otherwise.
- firstTime - Variable in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- firstValue - Variable in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- firstWriteByte(MetaSerdeHelper.ByteFieldWriter<T>) - Static method in class org.apache.druid.segment.serde.MetaSerdeHelper
- FIVE_MINUTE - org.apache.druid.java.util.common.granularity.GranularityType
- FIVE_MINUTE - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- fixed(int, String) - Static method in class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
- FIXED_BUCKET_HIST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- fixedFormatReader(InputRowSchema, File) - Method in class org.apache.druid.data.input.AbstractInputSource
- FixedIndexed<T> - Class in org.apache.druid.segment.data
-
Fixed width value implementation of
Indexed
, stored simply as a header that contains the number of values, and then the values stored sequentially. - FixedIndexedIntWriter - Class in org.apache.druid.segment.data
-
Specialized version of
FixedIndexedWriter
for writing ints, with no support for null values, and no verification that data is actually sorted, it just trusts you and takes your word for it - FixedIndexedIntWriter(SegmentWriteOutMedium, boolean) - Constructor for class org.apache.druid.segment.data.FixedIndexedIntWriter
- FixedIndexedWriter<T> - Class in org.apache.druid.segment.data
-
Writer for a
FixedIndexed
- FixedIndexedWriter(SegmentWriteOutMedium, TypeStrategy<T>, ByteOrder, int, boolean) - Constructor for class org.apache.druid.segment.data.FixedIndexedWriter
- FixedWidthGroupByColumnSelectorStrategy<T> - Class in org.apache.druid.query.groupby.epinephelinae.column
-
Strategy for grouping dimensions which have fixed-width objects.
- FixedWidthGroupByColumnSelectorStrategy(int, ColumnType, Function<ColumnValueSelector<?>, T>, Function<ColumnValueSelector<?>, Boolean>) - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.FixedWidthGroupByColumnSelectorStrategy
- flags - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- flatMap(Function<? super T, ? extends Sequence<? extends R>>) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- flatMap(Function<T, CloseableIterator<R>>) - Method in interface org.apache.druid.java.util.common.parsers.CloseableIterator
- flatMerge(Function<? super T, ? extends Sequence<? extends R>>, Ordering<? super R>) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- flatten(Expr) - Static method in class org.apache.druid.math.expr.Parser
- flatten(Filter) - Static method in class org.apache.druid.segment.filter.cnf.HiveCnfHelper
- flatten(T) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlattener
-
Transforms an input row object into a
Map
, likely based on the instructions in someJSONPathSpec
. - FlattenerJsonProvider - Class in org.apache.druid.java.util.common.parsers
- FlattenerJsonProvider() - Constructor for class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- FlatTextInputFormat - Class in org.apache.druid.data.input.impl
- flipBitAsBinaryString(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- FLOAT - org.apache.druid.segment.column.ValueType
-
32-bit single precision floating point number primitive type.
- FLOAT - org.apache.druid.segment.MetricHolder.MetricType
- FLOAT - Static variable in class org.apache.druid.segment.column.ColumnType
-
Druid 32-bit single precision floating point number primitive type.
- FLOAT - Static variable in class org.apache.druid.segment.column.TypeStrategies
- FLOAT_ANY_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- FLOAT_ARRAY - Static variable in class org.apache.druid.segment.column.ColumnType
-
An array of Floats.
- 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
- FLOAT_TYPE_NAME - Static variable in class org.apache.druid.data.input.impl.DimensionSchema
- 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
- FloatArrayFieldReader - Class in org.apache.druid.frame.field
-
Reader for fields written by
NumericArrayFieldWriter.getFloatArrayFieldWriter(org.apache.druid.segment.ColumnValueSelector)
- FloatArrayFieldReader() - Constructor for class org.apache.druid.frame.field.FloatArrayFieldReader
- FloatArrayFrameColumnReader - Class in org.apache.druid.frame.read.columnar
-
Reader for columns written by
FloatArrayFrameColumnWriter
- FloatArrayFrameColumnReader(int) - Constructor for class org.apache.druid.frame.read.columnar.FloatArrayFrameColumnReader
- FloatArrayFrameColumnWriter - Class in org.apache.druid.frame.write.columnar
-
Columnar frame writer for
ColumnType.FLOAT_ARRAY
columns - FloatArrayFrameColumnWriter(ColumnValueSelector, MemoryAllocator) - Constructor for class org.apache.druid.frame.write.columnar.FloatArrayFrameColumnWriter
- 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
- FloatCardinalityVectorProcessor - Class in org.apache.druid.query.aggregation.cardinality.vector
- FloatCardinalityVectorProcessor(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.cardinality.vector.FloatCardinalityVectorProcessor
- FloatColumnAccessorBase - Class in org.apache.druid.query.rowsandcols.column.accessor
- FloatColumnAccessorBase() - Constructor for class org.apache.druid.query.rowsandcols.column.accessor.FloatColumnAccessorBase
- FloatColumnSelector - Interface in org.apache.druid.segment
-
This interface is convenient for implementation of "float-sourcing"
ColumnValueSelector
s, it provides default implementations for allColumnValueSelector
's methods exceptBaseFloatColumnValueSelector.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
- FloatDimensionSchema - Class in org.apache.druid.data.input.impl
- FloatDimensionSchema(String) - Constructor for class org.apache.druid.data.input.impl.FloatDimensionSchema
- FloatFieldReader - Class in org.apache.druid.frame.field
-
Reads values written by
FloatFieldWriter
. - FloatFieldWriter - Class in org.apache.druid.frame.field
-
Wraps a
BaseFloatColumnValueSelector
and writes field values. - FloatFirstAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- FloatFirstAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregator
- FloatFirstAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.first
- FloatFirstAggregatorFactory(String, String, String) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- FloatFirstBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- FloatFirstBufferAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.FloatFirstBufferAggregator
- FloatFirstLastVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast
-
Vectorized version of on heap 'last' aggregator for column selectors with type FLOAT.
- FloatFirstLastVectorAggregator(VectorValueSelector, VectorObjectSelector, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- FloatFirstLastVectorAggregator(VectorValueSelector, VectorValueSelector, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- FloatFirstVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- FloatFirstVectorAggregator(VectorValueSelector, VectorObjectSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.FloatFirstVectorAggregator
- FloatFirstVectorAggregator(VectorValueSelector, VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.FloatFirstVectorAggregator
- FloatFrameColumnReader - Class in org.apache.druid.frame.read.columnar
- FloatFrameColumnWriter - Class in org.apache.druid.frame.write.columnar
- FloatFrameMaker - Class in org.apache.druid.frame.write.columnar
- FloatFrameMaker(MemoryAllocator, boolean) - Constructor for class org.apache.druid.frame.write.columnar.FloatFrameMaker
- FloatGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
- FloatLastAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- FloatLastAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregator
- FloatLastAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.last
- FloatLastAggregatorFactory(String, String, String) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- FloatLastBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- FloatLastBufferAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.FloatLastBufferAggregator
- FloatLastVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- FloatLastVectorAggregator(VectorValueSelector, VectorObjectSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.FloatLastVectorAggregator
- FloatLastVectorAggregator(VectorValueSelector, VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.FloatLastVectorAggregator
- 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) - Constructor for class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
- FloatMaxAggregatorFactory(String, String, String, ExprMacroTable) - 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) - Constructor for class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
- FloatMinAggregatorFactory(String, String, String, ExprMacroTable) - 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.NilVectorAggregator
- 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) - Constructor for class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
- FloatSumAggregatorFactory(String, String, String, ExprMacroTable) - 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, Object>) - Constructor for class org.apache.druid.query.topn.types.FloatTopNColumnAggregatesProcessor
- FloatTypeStrategy() - Constructor for class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- 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
- floor(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Floor() - Constructor for class org.apache.druid.math.expr.Function.Floor
- FluentQueryRunner<T> - Class in org.apache.druid.query
- FluentQueryRunner(QueryRunner<T>, QueryToolChest<T, Query<T>>) - Constructor for class org.apache.druid.query.FluentQueryRunner
- flush() - Method in class org.apache.druid.java.util.emitter.core.ComposingEmitter
- flush() - Method in interface org.apache.druid.java.util.emitter.core.Emitter
- flush() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- flush() - Method in class org.apache.druid.java.util.emitter.core.LoggingEmitter
- flush() - Method in class org.apache.druid.java.util.emitter.core.NoopEmitter
- flush() - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitter
- flush() - Method in class org.apache.druid.java.util.emitter.core.SwitchingEmitter
-
Triggers this emitter to tell all emitters that this uses to flush.
- flush() - Method in class org.apache.druid.java.util.emitter.service.ServiceEmitter
- 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.ArrayQuantileExprMacro
- 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
- FN_NAME - Static variable in class org.apache.druid.query.expression.IPv6AddressMatchExprMacro
- fnArgs() - Method in class org.apache.druid.math.expr.antlr.ExprParser.ApplyFunctionExprContext
- fnArgs() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- fnArgs() - Method in class org.apache.druid.math.expr.antlr.ExprParser.FunctionExprContext
- FnArgsContext() - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.FnArgsContext
- FnArgsContext(ParserRuleContext, int) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.FnArgsContext
- fold(ByteBuffer) - Method in class org.apache.druid.hll.HyperLogLogCollector
- fold(HyperLogLogCollector) - Method in class org.apache.druid.hll.HyperLogLogCollector
- fold(Histogram) - Method in class org.apache.druid.query.aggregation.Histogram
- fold(ColumnAnalysis) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- 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.firstlast.first.GenericFirstAggregateCombiner
- fold(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.firstlast.last.GenericLastAggregateCombiner
- fold(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongSumAggregateCombiner
- fold(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
- FoldFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.FoldFunction
- foldUnappliedBindings(Expr, Expr.BindingAnalysis, List<String>, String) - Static method in class org.apache.druid.math.expr.Parser
- forArray() - Static method in class org.apache.druid.frame.field.DoubleFieldReader
- forArray() - Static method in class org.apache.druid.frame.field.FloatFieldReader
- forArray() - Static method in class org.apache.druid.frame.field.LongFieldReader
- forArray(BaseDoubleColumnValueSelector) - Static method in class org.apache.druid.frame.field.DoubleFieldWriter
- forArray(BaseFloatColumnValueSelector) - Static method in class org.apache.druid.frame.field.FloatFieldWriter
- Forbidden - Class in org.apache.druid.error
- FORBIDDEN - org.apache.druid.error.DruidException.Category
-
Means that an action that was attempted is forbidden
- FORCE - org.apache.druid.query.QueryContexts.Vectorize
- FORCE_GUARANTEED_ROLLUP_COMPATIBLE - Static variable in interface org.apache.druid.indexer.partitions.DimensionBasedPartitionsSpec
-
Message denoting that this spec is forceGuaranteedRollup compatible.
- forColumn(String) - Static method in class org.apache.druid.query.filter.NullFilter
- forColumnIndexer(ColumnCapabilities) - Static method in class org.apache.druid.segment.column.CapabilitiesBasedFormat
- forEach(Consumer<? super T>) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- forEach(IntConsumer) - Method in interface org.apache.druid.segment.data.IndexedInts
- forEachEmitter(BiConsumer<URI, HttpPostEmitter>) - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitter
- forExpression(String, String, ExprMacroTable) - Static method in class org.apache.druid.segment.join.JoinConditionAnalysis
-
Analyze a join condition.
- forExpression(String, Expr, String) - Static method in class org.apache.druid.segment.join.JoinConditionAnalysis
-
Analyze a join condition from a pre-parsed expression.
- 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
- forInputSupplier(String, ExpressionType, Supplier<?>) - Static method in class org.apache.druid.math.expr.InputBindings
-
Create a
Expr.ObjectBinding
for a single input value of a known type provided by someSupplier
- forInputSupplier(ExpressionType, Supplier<?>) - Static method in class org.apache.druid.math.expr.InputBindings
-
Create a
Expr.ObjectBinding
for a single input value of a known type provided by someSupplier
- forInputSuppliers(Map<String, InputBindings.InputSupplier<?>>) - Static method in class org.apache.druid.math.expr.InputBindings
-
Create
Expr.ObjectBinding
backed by map ofSupplier
to provide values for identifiers to evaluateExpr
- forMap(Map<String, ?>) - Static method in class org.apache.druid.math.expr.InputBindings
-
Deprecated.
- forMap(Map<String, ?>, Expr.InputBindingInspector) - Static method in class org.apache.druid.math.expr.InputBindings
-
Create
Expr.ObjectBinding
backed byMap
to provide values for identifiers to evaluateExpr
Types are detected and values are coereced viaExprEval.bestEffortOf(Object)
because input types are currently unknown. - format(long, long, HumanReadableBytes.UnitSystem) - Static method in class org.apache.druid.java.util.common.HumanReadableBytes
-
Returns a human-readable string version of input value
- format(String, Object...) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Equivalent of String.format(Locale.ENGLISH, message, formatArgs).
- Format(ColumnType, boolean, boolean) - Constructor for class org.apache.druid.segment.nested.NestedCommonFormatColumn.Format
- formatMessage(String) - Static method in exception org.apache.druid.segment.data.ColumnCapacityExceededException
- formatRow(InputRow) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- formattableReader(InputRowSchema, InputFormat, File) - Method in class org.apache.druid.data.input.AbstractInputSource
- formattableReader(InputRowSchema, InputFormat, File) - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- formattableReader(InputRowSchema, InputFormat, File) - Method in class org.apache.druid.data.input.impl.HttpInputSource
- formattableReader(InputRowSchema, InputFormat, File) - Method in class org.apache.druid.data.input.impl.InlineInputSource
- formattableReader(InputRowSchema, InputFormat, File) - Method in class org.apache.druid.data.input.impl.LocalInputSource
- forOrderBy(ColumnWithDirection...) - Static method in class org.apache.druid.query.operator.window.WindowFrame
- forPersona(DruidException.Persona) - Method in class org.apache.druid.error.DruidException.DruidExceptionBuilder
- forPersona(DruidException.Persona) - Static method in exception org.apache.druid.error.DruidException
-
Starts building a "general" DruidException targeting the specified persona.
- forPredicate(DruidPredicateFactory) - Method in class org.apache.druid.segment.index.IndexedStringDruidPredicateIndexes
- forPredicate(DruidPredicateFactory) - Method in interface org.apache.druid.segment.index.semantic.DruidPredicateIndexes
-
Get a
BitmapColumnIndex
corresponding to all the rows that match the suppliedDruidPredicateFactory
- forPrimitive() - Static method in class org.apache.druid.frame.field.DoubleFieldReader
- forPrimitive() - Static method in class org.apache.druid.frame.field.FloatFieldReader
- forPrimitive() - Static method in class org.apache.druid.frame.field.LongFieldReader
- forPrimitive(BaseDoubleColumnValueSelector) - Static method in class org.apache.druid.frame.field.DoubleFieldWriter
- forPrimitive(BaseFloatColumnValueSelector) - Static method in class org.apache.druid.frame.field.FloatFieldWriter
- forPrimitive(BaseLongColumnValueSelector) - Static method in class org.apache.druid.frame.field.LongFieldWriter
- forQuery(Query<?>) - Static method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
- forRange(Number, boolean, Number, boolean) - Method in interface org.apache.druid.segment.index.semantic.NumericRangeIndexes
-
Get a
BitmapColumnIndex
corresponding to the values supplied in the specified range. - forRange(String, boolean, String, boolean) - Method in class org.apache.druid.segment.index.IndexedUtf8LexicographicalRangeIndexes
- forRange(String, boolean, String, boolean) - Method in interface org.apache.druid.segment.index.semantic.LexicographicalRangeIndexes
-
Get a
BitmapColumnIndex
corresponding to the values supplied in the specified range. - forRange(String, boolean, String, boolean, DruidObjectPredicate<String>) - Method in class org.apache.druid.segment.index.IndexedUtf8LexicographicalRangeIndexes
- forRange(String, boolean, String, boolean, DruidObjectPredicate<String>) - Method in interface org.apache.druid.segment.index.semantic.LexicographicalRangeIndexes
-
Get a
BitmapColumnIndex
corresponding to the values supplied in the specified range whose dictionary ids also match some predicate, such as to match a prefix. - forRow(Row) - Static method in class org.apache.druid.math.expr.InputBindings
-
Creates a
Expr.ObjectBinding
backed by someRow
. - forSegments(Iterable<DataSegment>) - Static method in class org.apache.druid.timeline.SegmentTimeline
- forSegments(Iterator<DataSegment>) - Static method in class org.apache.druid.timeline.SegmentTimeline
- forServer() - Method in class org.apache.druid.guice.StartupInjectorBuilder
- forSortedValues(List<?>, TypeSignature<ValueType>) - Method in class org.apache.druid.segment.index.IndexedUtf8ValueIndexes
- forSortedValues(List<?>, TypeSignature<ValueType>) - Method in interface org.apache.druid.segment.index.semantic.ValueSetIndexes
-
Get the wrapped
ImmutableBitmap
corresponding to the specified set of values (if they are contained in the underlying column). - forSortedValues(SortedSet<String>) - Method in class org.apache.druid.segment.index.IndexedUtf8ValueIndexes
- forSortedValues(SortedSet<String>) - Method in interface org.apache.druid.segment.index.semantic.StringValueSetIndexes
-
Deprecated.Get the wrapped
ImmutableBitmap
corresponding to the specified set of values (if they are contained in the underlying column). - forSortedValuesUtf8(List<ByteBuffer>) - Method in class org.apache.druid.segment.index.IndexedUtf8ValueIndexes
- forSortedValuesUtf8(List<ByteBuffer>) - Method in interface org.apache.druid.segment.index.semantic.Utf8ValueSetIndexes
-
Get the wrapped
ImmutableBitmap
corresponding to the specified set of values (if they are contained in the underlying column). - forTests() - Method in class org.apache.druid.guice.StartupInjectorBuilder
-
Configure the injector to not load server-only classes by binding those classes to providers of null values.
- forType(ColumnType) - Static method in class org.apache.druid.query.groupby.epinephelinae.column.DictionaryBuildingGroupByColumnSelectorStrategy
-
Creates an implementation of the strategy for the given type
- forValue(Object, TypeSignature<ValueType>) - Method in class org.apache.druid.segment.index.IndexedUtf8ValueIndexes
- forValue(Object, TypeSignature<ValueType>) - Method in interface org.apache.druid.segment.index.semantic.ValueIndexes
-
Get a
BitmapColumnIndex
which can compute theImmutableBitmap
corresponding to rows matching the supplied value. - forValue(String) - Static method in enum org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
- forValue(String) - Method in class org.apache.druid.segment.index.IndexedUtf8ValueIndexes
- forValue(String) - Method in interface org.apache.druid.segment.index.semantic.StringValueSetIndexes
-
Deprecated.Get the wrapped
ImmutableBitmap
corresponding to the supplied value. - forVersion(byte) - Static method in enum org.apache.druid.frame.FrameType
-
Returns the frame type for a particular version byte, or null if the version byte is unrecognized.
- ForwardingQueryProcessingPool - Class in org.apache.druid.query
-
Default implementation of
QueryProcessingPool
that just forwards operations, including query execution tasks, to an underlyingExecutorService
- ForwardingQueryProcessingPool(ExecutorService) - Constructor for class org.apache.druid.query.ForwardingQueryProcessingPool
- 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
- found(int, int) - Static method in class org.apache.druid.query.rowsandcols.util.FindResult
- 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
- frame() - Method in class org.apache.druid.frame.channel.FrameWithPartition
- frame(int) - Method in class org.apache.druid.frame.file.FrameFile
-
Reads a frame from the file.
- Frame - Class in org.apache.druid.frame
-
A data frame.
- FrameBasedIndexedTable - Class in org.apache.druid.segment.join.table
- FrameBasedIndexedTable(FrameBasedInlineDataSource, Set<String>, String) - Constructor for class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- FrameBasedInlineDataSource - Class in org.apache.druid.query
-
Represents an inline datasource where the rows are embedded within the DataSource object itself.
- FrameBasedInlineDataSource(List<FrameSignaturePair>, RowSignature) - Constructor for class org.apache.druid.query.FrameBasedInlineDataSource
- FrameBasedInlineDataSourceSerializer - Class in org.apache.druid.query
-
Serializes
FrameBasedInlineDataSource
to the representation ofInlineDataSource
so that the servers' on wire transfer data doesn't change. - FrameBasedInlineDataSourceSerializer() - Constructor for class org.apache.druid.query.FrameBasedInlineDataSourceSerializer
- FrameBasedInlineJoinableFactory - Class in org.apache.druid.segment.join
-
Creates a joinable from the
FrameBasedInlineDataSource
. - FrameBasedInlineJoinableFactory() - Constructor for class org.apache.druid.segment.join.FrameBasedInlineJoinableFactory
- FrameChannelBatcher - Class in org.apache.druid.frame.processor
-
Processor that reads up to "maxFrames" frames from some input channels and combines them into a batch.
- FrameChannelBatcher(List<ReadableFrameChannel>, int) - Constructor for class org.apache.druid.frame.processor.FrameChannelBatcher
- FrameChannelHashPartitioner - Class in org.apache.druid.frame.processor
-
Processor that hash-partitions rows from any number of input channels, and writes partitioned frames to output channels.
- FrameChannelHashPartitioner(List<ReadableFrameChannel>, List<WritableFrameChannel>, FrameReader, int, FrameWriterFactory) - Constructor for class org.apache.druid.frame.processor.FrameChannelHashPartitioner
- FrameChannelMerger - Class in org.apache.druid.frame.processor
-
Processor that merges already-sorted inputChannels and writes a fully-sorted stream to a single outputChannel.
- FrameChannelMerger(List<ReadableFrameChannel>, FrameReader, WritableFrameChannel, FrameWriterFactory, List<KeyColumn>, ClusterByPartitions, long) - Constructor for class org.apache.druid.frame.processor.FrameChannelMerger
- FrameChannelMixer - Class in org.apache.druid.frame.processor
-
Processor that merges frames from inputChannels into a single outputChannel.
- FrameChannelMixer(List<ReadableFrameChannel>, WritableFrameChannel) - Constructor for class org.apache.druid.frame.processor.FrameChannelMixer
- FrameChannelSequence - Class in org.apache.druid.frame.channel
- FrameChannelSequence(ReadableFrameChannel) - Constructor for class org.apache.druid.frame.channel.FrameChannelSequence
- FrameChannelSequence.FrameChannelIterator - Class in org.apache.druid.frame.channel
- FrameColumnReader - Interface in org.apache.druid.frame.read.columnar
-
Embeds the logic to read a specific column from frames with a specific
RowSignature
. - FrameColumnReaders - Class in org.apache.druid.frame.read.columnar
-
Creates
FrameColumnReader
corresponding to a given column type and number. - FrameColumnReaderUtils - Class in org.apache.druid.frame.read.columnar
- FrameColumnReaderUtils() - Constructor for class org.apache.druid.frame.read.columnar.FrameColumnReaderUtils
- FrameColumnSelectorFactory - Class in org.apache.druid.frame.segment.row
- FrameColumnSelectorFactory(Frame, RowSignature, List<FieldReader>, ReadableFrameRowPointer) - Constructor for class org.apache.druid.frame.segment.row.FrameColumnSelectorFactory
- FrameColumnWriter - Interface in org.apache.druid.frame.write.columnar
-
Represent writers for the columnar frames.
- FrameColumnWriters - Class in org.apache.druid.frame.write.columnar
- FrameComparisonWidget - Interface in org.apache.druid.frame.key
-
Wraps a
Frame
and provides ways to compare rows of that frame to various other things. - FrameComparisonWidgetImpl - Class in org.apache.druid.frame.key
-
Implementation of
FrameComparisonWidget
for pairs ofFrameType.ROW_BASED
frames. - FrameCursor - Class in org.apache.druid.frame.segment
- FrameCursor(SimpleSettableOffset, ColumnSelectorFactory) - Constructor for class org.apache.druid.frame.segment.FrameCursor
- FrameCursorFactory - Class in org.apache.druid.frame.segment.columnar
-
A
CursorFactory
implementation based on a single columnarFrame
. - FrameCursorFactory - Class in org.apache.druid.frame.segment.row
-
A
CursorFactory
implementation based on a single row-basedFrame
. - FrameCursorFactory(Frame, FrameReader, List<FieldReader>) - Constructor for class org.apache.druid.frame.segment.row.FrameCursorFactory
- FrameCursorFactory(Frame, RowSignature, List<FrameColumnReader>) - Constructor for class org.apache.druid.frame.segment.columnar.FrameCursorFactory
- FrameCursorUtils - Class in org.apache.druid.frame.segment
- FramedOnHeapAggregatable - Interface in org.apache.druid.query.rowsandcols.semantic
-
A semantic interface used to aggregate a list of AggregatorFactories across a given set of data
- FrameFile - Class in org.apache.druid.frame.file
-
A file containing
Frame
data. - FrameFile.Flag - Enum in org.apache.druid.frame.file
- FrameFileFooter - Class in org.apache.druid.frame.file
-
Encapsulation for Æ’rame file footer related operations.
- FrameFileFooter(Memory, long) - Constructor for class org.apache.druid.frame.file.FrameFileFooter
- FrameFileHttpResponseHandler - Class in org.apache.druid.frame.file
-
An
HttpResponseHandler
that streams data into aReadableByteChunksFrameChannel
. - FrameFileHttpResponseHandler(ReadableByteChunksFrameChannel) - Constructor for class org.apache.druid.frame.file.FrameFileHttpResponseHandler
- FrameFilePartialFetch - Class in org.apache.druid.frame.file
-
Response object for
FrameFileHttpResponseHandler
. - FrameFileWriter - Class in org.apache.druid.frame.file
-
Writer for
FrameFile
. - FrameFilteredOffset - Class in org.apache.druid.frame.segment
-
Copy of
FilteredOffset
that does not require bitmap indexes. - FrameFilteredOffset(SimpleSettableOffset, ColumnSelectorFactory, Filter) - Constructor for class org.apache.druid.frame.segment.FrameFilteredOffset
- FrameProcessor<T> - Interface in org.apache.druid.frame.processor
-
A FrameProcessor is like an incremental version of Runnable that operates on
ReadableFrameChannel
andWritableFrameChannel
. - FrameProcessorExecutor - Class in org.apache.druid.frame.processor
-
Manages execution of
FrameProcessor
in anExecutorService
. - FrameProcessorExecutor(ListeningExecutorService) - Constructor for class org.apache.druid.frame.processor.FrameProcessorExecutor
- FrameProcessors - Class in org.apache.druid.frame.processor
- FrameQueryableIndex - Class in org.apache.druid.frame.segment.columnar
-
A
QueryableIndex
implementation based on a single columnarFrame
. - FrameQueryableIndex(Frame, RowSignature, List<FrameColumnReader>) - Constructor for class org.apache.druid.frame.segment.columnar.FrameQueryableIndex
- FrameReader - Class in org.apache.druid.frame.read
-
Embeds the logic to read frames with a given
RowSignature
. - FrameReaderUtils - Class in org.apache.druid.frame.read
-
Utility methods used by various entities that read data from
Frame
objects. - FrameReaderUtils() - Constructor for class org.apache.druid.frame.read.FrameReaderUtils
- FrameRowTooLargeException - Exception in org.apache.druid.frame.processor
-
Exception that is conventionally thrown by workers when they call
FrameWriter.addSelection()
and it returns false on an empty frame, or in a situation where allocating a new frame is impractical. - FrameRowTooLargeException(long) - Constructor for exception org.apache.druid.frame.processor.FrameRowTooLargeException
- FrameSegment - Class in org.apache.druid.frame.segment
- FrameSegment(Frame, FrameReader, SegmentId) - Constructor for class org.apache.druid.frame.segment.FrameSegment
- FrameSignaturePair - Class in org.apache.druid.query
-
Encapsulates a
Frame
and theRowSignature
of the rows that are encapsulated in it - FrameSignaturePair(Frame, RowSignature) - Constructor for class org.apache.druid.query.FrameSignaturePair
- FrameSort - Class in org.apache.druid.frame.write
-
Utility for sorting frames in-place.
- FrameStorageAdapter - Class in org.apache.druid.frame.segment
-
A
StorageAdapter
implementation based on a singleFrame
. - FrameStorageAdapter(Frame, FrameReader, Interval) - Constructor for class org.apache.druid.frame.segment.FrameStorageAdapter
- frameType() - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriterFactory
- frameType() - Method in interface org.apache.druid.frame.write.FrameWriterFactory
- frameType() - Method in class org.apache.druid.frame.write.RowBasedFrameWriterFactory
- FrameType - Enum in org.apache.druid.frame
- FrameVectorCursor - Class in org.apache.druid.frame.segment.columnar
-
A
VectorCursor
that is based on aFrame
. - FrameWithPartition - Class in org.apache.druid.frame.channel
-
Frame plus partition number.
- FrameWithPartition(Frame, int) - Constructor for class org.apache.druid.frame.channel.FrameWithPartition
- FrameWriter - Interface in org.apache.druid.frame.write
-
Writer for
Frame
. - FrameWriterFactory - Interface in org.apache.druid.frame.write
-
Interface for creating
FrameWriter
. - FrameWriters - Class in org.apache.druid.frame.write
-
Outward-facing utility methods for
FrameWriterFactory
andFrameWriter
users. - FrameWriterUtils - Class in org.apache.druid.frame.write
-
Utility methods used by
FrameWriter
implementations. - FrameWriterUtils() - Constructor for class org.apache.druid.frame.write.FrameWriterUtils
- free() - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
- free(ByteBuffer) - Static method in class org.apache.druid.java.util.common.ByteBufferUtils
-
Releases memory held by the given direct ByteBuffer
- from(float[], float[]) - Static method in class org.apache.druid.collections.spatial.search.PolygonBound
- from(float[], float[], int) - Static method in class org.apache.druid.collections.spatial.search.PolygonBound
-
abscissa and ordinate contain the coordinates of polygon.
- from(String, Character) - Static method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
- from(QueryRunner<T>) - Method in class org.apache.druid.query.FluentQueryRunner
- fromAccumulator(Accumulator<AccumulatedType, InType>) - Static method in class org.apache.druid.java.util.common.guava.YieldingAccumulators
- 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
- fromArray(T[], ObjectStrategy<T>) - Static method in class org.apache.druid.segment.data.GenericIndexed
- fromBase(String) - Static method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- fromByte(byte) - Static method in enum org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.VERSION
- fromByteBuffer(String, ByteBuffer, ByteOrder, SmooshedFileMapper) - Static method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSupplier
- fromByteBuffer(ByteBuffer) - Static method in class org.apache.druid.segment.MetricHolder
- 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.CompressedBlockReader
- 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) - Static method in class org.apache.druid.segment.data.CompressedColumnarLongsSupplier
- fromByteBuffer(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.CompressedLongsReader
- fromByteBuffer(ByteBuffer, ByteOrder) - 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, ByteOrder) - Static method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
- fromByteBuffer(ByteBuffer, ByteOrder, SmooshedFileMapper) - Static method in class org.apache.druid.segment.data.CompressedColumnarIntsSupplier
- fromByteBuffer(ByteBuffer, ByteOrder, SmooshedFileMapper) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
- fromByteBuffer(ByteBuffer, ByteOrder, SmooshedFileMapper) - Static method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
- fromByteBufferSafe(ByteBuffer, int) - Method in interface org.apache.druid.segment.data.ObjectStrategy
-
Convert values from their underlying byte representation, when the underlying bytes might be corrupted or maliciously constructed Implementations of this method absolutely must never perform any sun.misc.Unsafe based memory read or write operations from instructions contained in the data read from this buffer without first validating the data.
- 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(byte[]) - Static method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
- fromBytes(byte[]) - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- fromBytes(byte[]) - Method in interface org.apache.druid.segment.column.TypeStrategy
-
Translate raw byte array into a value.
- fromBytes(byte[], int, int) - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
-
Converts byte[] to intermediate representation of the aggregate.
- fromBytes(ByteBuffer) - Static method in class org.apache.druid.query.aggregation.Histogram
- fromCloseable(T) - Static method in class org.apache.druid.collections.ReferenceCountingResourceHolder
- fromCloseable(T) - Static method in interface org.apache.druid.collections.ResourceHolder
- fromCode(String, TaskState) - Static method in class org.apache.druid.indexer.TaskStatus
-
This method is deprecated for production because it does not handle the error message of failed task status properly.
- fromColumn(Column) - Static method in interface org.apache.druid.query.rowsandcols.column.BinarySearchableAccessor
- fromColumnType(TypeSignature<ValueType>) - Static method in class org.apache.druid.math.expr.ExpressionType
-
The expression system does not distinguish between
ValueType.FLOAT
andValueType.DOUBLE
, so this method will convertValueType.FLOAT
toExpressionType.DOUBLE
. - fromColumnTypeStrict(TypeSignature<ValueType>) - Static method in class org.apache.druid.math.expr.ExpressionType
-
The expression system does not distinguish between
ValueType.FLOAT
andValueType.DOUBLE
, so, this method will convertValueType.FLOAT
toExpressionType.DOUBLE
. - fromErrorCode(String) - Static method in exception org.apache.druid.query.QueryException
- fromFailure(DruidException.Failure) - Static method in exception org.apache.druid.error.DruidException
-
Builds a DruidException using the provided Failure class.
- fromFieldName(String) - Static method in enum org.apache.druid.data.input.impl.systemfield.SystemField
- fromFileName(String) - Static method in enum org.apache.druid.utils.CompressionUtils.Format
- fromIndexedInts(IndexedInts, int) - Static method in class org.apache.druid.segment.data.VSizeColumnarInts
- fromInputSource(SystemFieldInputSource) - Static method in class org.apache.druid.data.input.impl.systemfield.SystemFieldDecoratorFactory
-
Create a decorator factory for a given
SystemFieldInputSource
. - fromIterable(Iterable<Object[]>, RowSignature) - Static method in class org.apache.druid.query.InlineDataSource
-
Creates an inline datasource from an Iterable.
- fromIterable(Iterable<IndexedInts>, int, int, ByteOrder, CompressionStrategy, Closer) - Static method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
- fromIterable(Iterable<IndexedInts>, int, ByteOrder, CompressionStrategy, Closer) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier
- fromIterable(Iterable<VSizeColumnarInts>) - Static method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
- fromIterable(Iterable<T>, ObjectStrategy<T>) - Static method in class org.apache.druid.segment.data.GenericIndexed
- 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 givenGroupByQuery
. - 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
. - fromMap(Map<String, ? extends Column>) - Static method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- fromMap(Map<String, Object>) - Static method in class org.apache.druid.error.ErrorResponse
- fromMap(Map<String, String>) - Static method in class org.apache.druid.query.lookup.ImmutableLookupMap
-
Create an
ImmutableLookupMap
from a particular map. - fromPeriod(Period) - Static method in enum org.apache.druid.java.util.common.granularity.GranularityType
-
Note: This is only an estimate based on the values in period.
- fromRAC(RowsAndColumns) - Static method in interface org.apache.druid.query.rowsandcols.semantic.ClusteredGroupPartitioner
- fromRAC(RowsAndColumns) - Static method in interface org.apache.druid.query.rowsandcols.semantic.ColumnSelectorFactoryMaker
- fromRAC(RowsAndColumns) - Static method in interface org.apache.druid.query.rowsandcols.semantic.FramedOnHeapAggregatable
- fromRAC(RowsAndColumns) - Static method in interface org.apache.druid.query.rowsandcols.semantic.NaiveSortMaker
- fromRAC(RowsAndColumns) - Static method in interface org.apache.druid.query.rowsandcols.semantic.RowsAndColumnsDecorator
- fromRAC(RowsAndColumns) - Static method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker
- fromRAC(RowsAndColumns) - Static method in interface org.apache.druid.query.rowsandcols.semantic.WireTransferable
- fromResultRow(ArrayList<ResultRow>, RowSignature) - Static method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- fromRoaringBitmapIntIterator(IntIterator) - Static method in class org.apache.druid.segment.IntIteratorUtils
- fromRowObjects(Object[][], RowSignature) - Static method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- fromString(String) - Static method in class org.apache.druid.audit.AuditEntry.Payload
- fromString(String) - Static method in enum org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
- fromString(String) - Static method in class org.apache.druid.java.util.common.granularity.Granularity
- fromString(String) - Static method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- fromString(String) - Static method in enum org.apache.druid.java.util.common.parsers.JSONPathFieldType
- fromString(String) - Static method in enum org.apache.druid.java.util.common.StringEncoding
- fromString(String) - Static method in class org.apache.druid.math.expr.ExpressionType
- fromString(String) - Static method in class org.apache.druid.metadata.DefaultPasswordProvider
- 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.AggregatorMergeStrategy
- 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 class org.apache.druid.segment.column.ColumnType
- fromString(String) - Static method in enum org.apache.druid.segment.column.ValueType
- 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
- fromString(String) - Static method in enum org.apache.druid.timeline.partition.HashPartitionFunction
- fromString(TypeFactory<T>, String) - Static method in class org.apache.druid.segment.column.Types
- fromTaskIdentifierInfo(TaskInfo<TaskIdentifier, TaskStatus>) - Static method in class org.apache.druid.indexer.TaskStatusPlus
-
Convert a TaskInfo class of TaskIdentifier and TaskStatus to a TaskStatusPlus Applicable only for completed or waiting tasks since a TaskInfo doesn't have the exhaustive info for running tasks
- fromTo(int, int) - Static method in class org.apache.druid.segment.IntListUtils
- fromUtf8(byte[]) - Static method in class org.apache.druid.java.util.common.StringUtils
- fromUtf8(byte[], int, int) - Static method in class org.apache.druid.java.util.common.StringUtils
- fromUtf8(ByteBuffer) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Decodes a UTF-8 string from the remaining bytes of a non-null buffer.
- fromUtf8(ByteBuffer, int) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Decodes a UTF-8 String from
numBytes
bytes starting at the current position of a buffer. - fromUtf8Nullable(ByteBuffer) - Static method in class org.apache.druid.java.util.common.StringUtils
-
If buffer is Decodes a UTF-8 string from the remaining bytes of a buffer.
- fromValueSelector(ColumnValueSelector<ExprEval>, ExtractionFn) - Static method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
- FRONT_CODED - Static variable in interface org.apache.druid.segment.column.StringEncodingStrategy
- FRONT_CODED_ID - Static variable in interface org.apache.druid.segment.column.StringEncodingStrategy
- FrontCoded(Integer) - Constructor for class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- FrontCoded(Integer, Byte) - Constructor for class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- FrontCodedIndexed - Class in org.apache.druid.segment.data
-
Indexed
specialized for storing variable-width binary values (such as utf8 encoded strings), which must be sorted and unique, using 'front coding'. - FrontCodedIndexed.FrontCodedV0 - Class in org.apache.druid.segment.data
- FrontCodedIndexed.FrontCodedV1 - Class in org.apache.druid.segment.data
- FrontCodedIndexedWriter - Class in org.apache.druid.segment.data
- FrontCodedIndexedWriter(SegmentWriteOutMedium, ByteOrder, int, byte) - Constructor for class org.apache.druid.segment.data.FrontCodedIndexedWriter
- FrontCodedIntArrayIndexed - Class in org.apache.druid.segment.data
-
Indexed
specialized for storing int arrays, which must be sorted and unique, using 'front coding'. - FrontCodedIntArrayIndexedWriter - Class in org.apache.druid.segment.data
- FrontCodedIntArrayIndexedWriter(SegmentWriteOutMedium, ByteOrder, int) - Constructor for class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- FULL - org.apache.druid.segment.join.JoinType
- FullResponseHolder<T> - Class in org.apache.druid.java.util.http.client.response
-
This class is to hold data while receiving stream data via HTTP.
- FullResponseHolder(HttpResponse) - Constructor for class org.apache.druid.java.util.http.client.response.FullResponseHolder
- function(ExpressionType, ExpressionType) - Static method in class org.apache.druid.math.expr.ExpressionTypeConversion
-
Given 2 'input' types, choose the most appropriate combined type, if possible arrays must be the same type if either type is
ExprType.STRING
, the output type will be preserved as string if both types areExprType.LONG
, the output type will be preserved as long, otherwiseExprType.DOUBLE
- Function - Interface in org.apache.druid.math.expr
-
Base interface describing the mechanism used to evaluate a
FunctionExpr
. - Function.Abs - Class in org.apache.druid.math.expr
- Function.Acos - Class in org.apache.druid.math.expr
- Function.ArrayAddElementFunction - Class in org.apache.druid.math.expr
-
Scaffolding for a 2 argument
Function
which accepts one array and one scalar input and adds the scalar input to the array in some way. - Function.ArrayAppendFunction - Class in org.apache.druid.math.expr
- Function.ArrayConcatFunction - Class in org.apache.druid.math.expr
- Function.ArrayConstructorFunction - Class in org.apache.druid.math.expr
- Function.ArrayContainsFunction - Class in org.apache.druid.math.expr
- Function.ArrayLengthFunction - Class in org.apache.druid.math.expr
- Function.ArrayOffsetFunction - Class in org.apache.druid.math.expr
- Function.ArrayOffsetOfFunction - Class in org.apache.druid.math.expr
- Function.ArrayOrdinalFunction - Class in org.apache.druid.math.expr
- Function.ArrayOrdinalOfFunction - Class in org.apache.druid.math.expr
- Function.ArrayOverlapFunction - Class in org.apache.druid.math.expr
- Function.ArrayPrependFunction - Class in org.apache.druid.math.expr
- Function.ArrayScalarFunction - Class in org.apache.druid.math.expr
-
Function
that takes 1 array operand and 1 scalar operand - Function.ArraySetAddAllFunction - Class in org.apache.druid.math.expr
- Function.ArraySetAddFunction - Class in org.apache.druid.math.expr
- Function.ArraysFunction - Class in org.apache.druid.math.expr
-
Function
that takes 2 array operands - Function.ArraySliceFunction - Class in org.apache.druid.math.expr
- Function.ArraysMergeFunction - Class in org.apache.druid.math.expr
-
Base scaffolding for functions which accept 2 array arguments and combine them in some way
- Function.ArrayToMultiValueStringFunction - Class in org.apache.druid.math.expr
- Function.ArrayToStringFunction - Class in org.apache.druid.math.expr
- Function.Asin - Class in org.apache.druid.math.expr
- Function.Atan - Class in org.apache.druid.math.expr
- Function.Atan2 - Class in org.apache.druid.math.expr
- Function.BitwiseAnd - Class in org.apache.druid.math.expr
- Function.BitwiseComplement - Class in org.apache.druid.math.expr
- Function.BitwiseConvertDoubleToLongBits - Class in org.apache.druid.math.expr
- Function.BitwiseConvertLongBitsToDouble - Class in org.apache.druid.math.expr
- Function.BitwiseOr - Class in org.apache.druid.math.expr
- Function.BitwiseShiftLeft - Class in org.apache.druid.math.expr
- Function.BitwiseShiftRight - Class in org.apache.druid.math.expr
- Function.BitwiseXor - Class in org.apache.druid.math.expr
- Function.BivariateBitwiseMathFunction - Class in org.apache.druid.math.expr
- Function.BivariateFunction - Class in org.apache.druid.math.expr
-
Base class for a 2 variable input
Function
implementation - Function.BivariateMathFunction - Class in org.apache.druid.math.expr
-
Base class for a 2 variable input mathematical
Function
, with specialized 'eval' implementations that operate on primitive number types - Function.CaseSearchedFunc - Class in org.apache.druid.math.expr
-
"Searched CASE" function, similar to
CASE WHEN boolean_expr THEN result [ELSE else_result] END
in SQL. - Function.CaseSimpleFunc - Class in org.apache.druid.math.expr
-
"Simple CASE" function, similar to
CASE expr WHEN value THEN result [ELSE else_result] END
in SQL. - Function.CastFunc - Class in org.apache.druid.math.expr
- Function.Cbrt - Class in org.apache.druid.math.expr
- Function.Ceil - Class in org.apache.druid.math.expr
- Function.CoalesceFunc - Class in org.apache.druid.math.expr
- Function.ConcatFunc - Class in org.apache.druid.math.expr
- Function.ConditionFunc - Class in org.apache.druid.math.expr
- Function.CopySign - Class in org.apache.druid.math.expr
- Function.Cos - Class in org.apache.druid.math.expr
- Function.Cosh - Class in org.apache.druid.math.expr
- Function.Cot - Class in org.apache.druid.math.expr
- Function.Div - Class in org.apache.druid.math.expr
- Function.DoubleBivariateMathFunction - Class in org.apache.druid.math.expr
-
Many math functions always output a
Double
primitive, regardless of input type. - Function.DoubleUnivariateMathFunction - Class in org.apache.druid.math.expr
-
Many math functions always output a
Double
primitive, regardless of input type. - Function.Exp - Class in org.apache.druid.math.expr
- Function.Expm1 - Class in org.apache.druid.math.expr
- Function.Floor - Class in org.apache.druid.math.expr
- Function.GetExponent - Class in org.apache.druid.math.expr
- Function.GreatestFunc - Class in org.apache.druid.math.expr
- Function.HumanReadableBinaryByteFormatFunc - Class in org.apache.druid.math.expr
- Function.HumanReadableDecimalByteFormatFunc - Class in org.apache.druid.math.expr
- Function.HumanReadableDecimalFormatFunc - Class in org.apache.druid.math.expr
- Function.Hypot - Class in org.apache.druid.math.expr
- Function.IsDistinctFromFunc - Class in org.apache.druid.math.expr
-
SQL function "x IS DISTINCT FROM y".
- Function.IsFalseFunc - Class in org.apache.druid.math.expr
-
SQL function "IS FALSE".
- Function.IsNotDistinctFromFunc - Class in org.apache.druid.math.expr
-
SQL function "x IS NOT DISTINCT FROM y".
- Function.IsNotFalseFunc - Class in org.apache.druid.math.expr
-
SQL function "IS NOT FALSE".
- Function.IsNotNullFunc - Class in org.apache.druid.math.expr
- Function.IsNotTrueFunc - Class in org.apache.druid.math.expr
-
SQL function "IS NOT TRUE".
- Function.IsNullFunc - Class in org.apache.druid.math.expr
- Function.IsTrueFunc - Class in org.apache.druid.math.expr
-
SQL function "IS TRUE".
- Function.LeastFunc - Class in org.apache.druid.math.expr
- Function.LeftFunc - Class in org.apache.druid.math.expr
- Function.Log - Class in org.apache.druid.math.expr
- Function.Log10 - Class in org.apache.druid.math.expr
- Function.Log1p - Class in org.apache.druid.math.expr
- Function.LowerFunc - Class in org.apache.druid.math.expr
- Function.LpadFunc - Class in org.apache.druid.math.expr
- Function.Max - Class in org.apache.druid.math.expr
- Function.Min - Class in org.apache.druid.math.expr
- Function.MultiValueStringHarmonizeNullsFunction - Class in org.apache.druid.math.expr
-
Primarily internal helper function used to coerce null, [], and [null] into [null], similar to the logic done by
ExpressionSelectors.supplierFromDimensionSelector(org.apache.druid.segment.DimensionSelector, boolean, boolean)
when the 3rd argument is true, which is done when implicitly mapping scalar functions over mvd values. - Function.MultiValueStringToArrayFunction - Class in org.apache.druid.math.expr
- Function.NextAfter - Class in org.apache.druid.math.expr
- Function.NextUp - Class in org.apache.druid.math.expr
- Function.NvlFunc - Class in org.apache.druid.math.expr
-
nvl is like coalesce, but accepts exactly two arguments.
- Function.ParseLong - Class in org.apache.druid.math.expr
- Function.Pi - Class in org.apache.druid.math.expr
- Function.Pow - Class in org.apache.druid.math.expr
- Function.ReduceFunction - Class in org.apache.druid.math.expr
- Function.Remainder - Class in org.apache.druid.math.expr
- Function.RepeatFunc - Class in org.apache.druid.math.expr
- Function.ReplaceFunc - Class in org.apache.druid.math.expr
- Function.ReverseFunc - Class in org.apache.druid.math.expr
- Function.RightFunc - Class in org.apache.druid.math.expr
- Function.Rint - Class in org.apache.druid.math.expr
- Function.Round - Class in org.apache.druid.math.expr
- Function.RpadFunc - Class in org.apache.druid.math.expr
- Function.SafeDivide - Class in org.apache.druid.math.expr
- Function.ScalarInArrayFunction - Class in org.apache.druid.math.expr
- Function.Scalb - Class in org.apache.druid.math.expr
- Function.Signum - Class in org.apache.druid.math.expr
- Function.Sin - Class in org.apache.druid.math.expr
- Function.Sinh - Class in org.apache.druid.math.expr
- Function.SizeFormatFunc - Class in org.apache.druid.math.expr
- Function.Sqrt - Class in org.apache.druid.math.expr
- Function.StringFormatFunc - Class in org.apache.druid.math.expr
- Function.StringLongFunction - Class in org.apache.druid.math.expr
-
Base class for a 2 variable input
Function
whose first argument is aExprType.STRING
and second argument isExprType.LONG
- Function.StringToArrayFunction - Class in org.apache.druid.math.expr
- Function.StrlenFunc - Class in org.apache.druid.math.expr
- Function.StrposFunc - Class in org.apache.druid.math.expr
- Function.SubMonthFunc - Class in org.apache.druid.math.expr
- Function.SubstringFunc - Class in org.apache.druid.math.expr
- Function.Tan - Class in org.apache.druid.math.expr
- Function.Tanh - Class in org.apache.druid.math.expr
- Function.TimestampFromEpochFunc - Class in org.apache.druid.math.expr
- Function.ToDegrees - Class in org.apache.druid.math.expr
- Function.ToRadians - Class in org.apache.druid.math.expr
- Function.Ulp - Class in org.apache.druid.math.expr
- Function.UnivariateFunction - Class in org.apache.druid.math.expr
-
Base class for a single variable input
Function
implementation - Function.UnivariateMathFunction - Class in org.apache.druid.math.expr
-
Base class for a single variable input mathematical
Function
, with specialized 'eval' implementations that that operate on primitive number types - Function.UnixTimestampFunc - Class in org.apache.druid.math.expr
- Function.UpperFunc - Class in org.apache.druid.math.expr
- 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
- FunctionalIterable<T> - Class in org.apache.druid.java.util.common.guava
- FunctionalIterable(Iterable<T>) - Constructor for class org.apache.druid.java.util.common.guava.FunctionalIterable
- FunctionalIterator<T> - Class in org.apache.druid.java.util.common.guava
- FunctionalIterator(Iterator<T>) - Constructor for class org.apache.druid.java.util.common.guava.FunctionalIterator
- FunctionArgsContext(ExprParser.FnArgsContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.FunctionArgsContext
- FunctionExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.FunctionExprContext
- FutureUtils - Class in org.apache.druid.common.guava
- FutureUtils() - Constructor for class org.apache.druid.common.guava.FutureUtils
- futureWithBaggage(ListenableFuture<T>, Closeable) - Static method in class org.apache.druid.common.guava.FutureUtils
-
Returns a future that resolves when "future" resolves and "baggage" has been closed.
G
- generate(String) - Method in class org.apache.druid.java.util.http.client.pool.ChannelResourceFactory
- generate(K) - Method in interface org.apache.druid.java.util.http.client.pool.ResourceFactory
- generateFieldNames(int) - Static method in class org.apache.druid.java.util.common.parsers.ParserUtils
- generateHeaderFileName(String) - Static method in class org.apache.druid.segment.data.GenericIndexedWriter
- generateRowValue() - Method in class org.apache.druid.segment.generator.ColumnValueGenerator
- generateUniquePath() - Static method in interface org.apache.druid.segment.loading.DataSegmentPusher
- generateUuid(String...) - Static method in class org.apache.druid.common.utils.UUIDUtils
-
Generates a universally unique identifier.
- 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.
- GenericFirstAggregateCombiner<T extends SerializablePair<Long,?>> - Class in org.apache.druid.query.aggregation.firstlast.first
- GenericFirstAggregateCombiner(Class<T>) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.GenericFirstAggregateCombiner
- GenericIndexed<T> - Class in org.apache.druid.segment.data
-
A generic, flat storage mechanism.
- GenericIndexed(ObjectStrategy<T>, boolean, int) - Constructor for class org.apache.druid.segment.data.GenericIndexed
- GenericIndexed.BufferIndexed - Class in org.apache.druid.segment.data
-
Single-threaded view.
- GenericIndexedBasedComplexColumn - Class in org.apache.druid.segment.column
-
Implementation of
ComplexColumn
to be used when complex column serialization is done by usingGenericIndexed
by using default implementations of "writeToXXX" methods inComplexColumnSerializer
- 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
The versionEncodedStringDictionaryWriter.VERSION
is reserved and must never be specified as theGenericIndexed
version byte, else it will interfere with string column deserialization. - 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
- GenericLastAggregateCombiner<T extends SerializablePair<Long,?>> - Class in org.apache.druid.query.aggregation.firstlast.last
- GenericLastAggregateCombiner(Class<T>) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.GenericLastAggregateCombiner
- 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. - GEQ - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- GEQ - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- get() - Method in class org.apache.druid.collections.CloseableResourceHolder
- get() - Method in class org.apache.druid.collections.ReferenceCountingResourceHolder
-
Returns the resource with an initial reference count of 1.
- get() - Method in interface org.apache.druid.collections.ResourceHolder
- get() - Method in class org.apache.druid.collections.StupidResourceHolder
- get() - Method in class org.apache.druid.common.guava.SettableSupplier
- get() - Method in class org.apache.druid.data.input.InputSplit
- get() - Method in class org.apache.druid.guice.ConfigProvider
-
Deprecated.
- get() - Method in class org.apache.druid.guice.JacksonConfigProvider
- get() - Method in class org.apache.druid.guice.JsonConfigProvider
- get() - Method in class org.apache.druid.guice.ListProvider
- get() - Method in class org.apache.druid.guice.ProviderBasedGoogleSupplierProvider
- get() - Method in class org.apache.druid.java.util.common.guava.ExecuteWhenDoneYielder
- get() - Method in interface org.apache.druid.java.util.common.guava.Yielder
-
Gets the object currently held by this Yielder.
- get() - Method in class org.apache.druid.java.util.common.MappedByteBufferHandler
-
Returns the wrapped buffer.
- get() - Method in interface org.apache.druid.java.util.http.client.pool.ResourceContainer
- get() - Method in class org.apache.druid.math.expr.InputBindings.InputSupplier
- get() - Method in interface org.apache.druid.query.aggregation.Aggregator
- get() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregator
- get() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregator
- get() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregator
- get() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
- get() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
- get() - Method in class org.apache.druid.query.aggregation.constant.LongConstantAggregator
- get() - Method in class org.apache.druid.query.aggregation.CountAggregator
- get() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
- get() - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregator
- get() - Method in class org.apache.druid.query.aggregation.DoubleMinAggregator
- get() - Method in class org.apache.druid.query.aggregation.DoubleSumAggregator
- get() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregator
- get() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
- get() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregator
- get() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregator
- get() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregator
- get() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- get() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregator
- get() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregator
- get() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregator
- get() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- get() - Method in class org.apache.druid.query.aggregation.FloatMaxAggregator
- get() - Method in class org.apache.druid.query.aggregation.FloatMinAggregator
- get() - Method in class org.apache.druid.query.aggregation.FloatSumAggregator
- get() - Method in class org.apache.druid.query.aggregation.HistogramAggregator
- get() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
- get() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
- get() - Method in class org.apache.druid.query.aggregation.LongMaxAggregator
- get() - Method in class org.apache.druid.query.aggregation.LongMinAggregator
- get() - Method in class org.apache.druid.query.aggregation.LongSumAggregator
- get() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregator
- get() - Method in class org.apache.druid.query.aggregation.NoopAggregator
- get() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
- get() - Method in class org.apache.druid.query.aggregation.SingleValueAggregator
- get() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
- 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() - 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.CompressedVariableSizedBlobColumnSupplier
- get() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
- 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() - Method in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
- get() - Method in class org.apache.druid.segment.data.VSizeColumnarInts
- get() - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
- get() - Method in class org.apache.druid.segment.generator.ColumnValueGenerator
- get() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
- get() - Method in interface org.apache.druid.segment.index.semantic.NullValueIndex
- get() - Method in class org.apache.druid.segment.nested.NestedDataColumnSupplier
- get() - Method in class org.apache.druid.segment.nested.NestedDataColumnSupplierV4
- get() - Method in class org.apache.druid.segment.nested.ScalarDoubleColumnAndIndexSupplier
- get() - Method in class org.apache.druid.segment.nested.ScalarLongColumnAndIndexSupplier
- get() - Method in class org.apache.druid.segment.nested.ScalarStringColumnAndIndexSupplier
- get() - Method in class org.apache.druid.segment.nested.VariantColumnAndIndexSupplier
- get() - Method in interface org.apache.druid.segment.serde.cell.ByteBufferProvider
- get() - Method in class org.apache.druid.segment.serde.cell.NativeClearedByteBufferProvider
- get() - Method in class org.apache.druid.segment.serde.ComplexColumnPartSupplier
- 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.StringUtf8DictionaryEncodedColumnSupplier
- get() - Method in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- get() - Method in class org.apache.druid.storage.local.LocalFileStorageConnectorProvider
- 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(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.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(int) - Method in class org.apache.druid.data.input.StringTuple
- get(int) - Method in class org.apache.druid.extendedset.utilities.IntList
- get(int) - Method in class org.apache.druid.frame.key.ClusterByPartitions
- get(int) - Method in class org.apache.druid.math.expr.CartesianList
- get(int) - Method in interface org.apache.druid.query.dimension.ListFilteredDimensionSpec.IndexedGetter
- get(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferIntList
- get(int) - Method in class org.apache.druid.query.groupby.ResultRow
- get(int) - Method in class org.apache.druid.segment.column.StringEncodingStrategies.Utf8ToStringIndexed
- get(int) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
- get(int) - Method in interface org.apache.druid.segment.data.ColumnarDoubles
- get(int) - Method in interface org.apache.druid.segment.data.ColumnarFloats
- get(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(int) - Method in class org.apache.druid.segment.data.CompressedLongsReader
- get(int) - Method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumn
- get(int) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
- get(int) - Method in interface org.apache.druid.segment.data.DictionaryWriter
- get(int) - Method in class org.apache.druid.segment.data.EncodedStringDictionaryWriter
- get(int) - Method in class org.apache.druid.segment.data.FixedIndexed
- get(int) - Method in class org.apache.druid.segment.data.FixedIndexedWriter
- get(int) - Method in class org.apache.druid.segment.data.FrontCodedIndexed
- get(int) - Method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
- get(int) - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexed
- get(int) - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- get(int) - Method in class org.apache.druid.segment.data.GenericIndexed.BufferIndexed
- get(int) - Method in class org.apache.druid.segment.data.GenericIndexedWriter
- get(int) - Method in interface org.apache.druid.segment.data.Indexed
-
Get the value at specified position
- get(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(int) - Method in class org.apache.druid.segment.data.VSizeColumnarInts
- get(int) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
- get(int) - Method in interface org.apache.druid.segment.data.VSizeLongSerde.LongDeserializer
-
Unpack long value at the specified row index
- get(int) - Method in class org.apache.druid.segment.data.ZeroIndexedInts
- get(int) - Method in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
- get(int) - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- get(int) - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesIndexedInts
- get(int) - Method in class org.apache.druid.segment.serde.ReplaceFirstValueWithNullIndexed
- get(int) - Method in class org.apache.druid.utils.CircularBuffer
-
Access object at a given index, starting from the earliest entry added and moving forward.
- get(int[], int[], int) - Method in interface org.apache.druid.segment.data.IndexedInts
- get(int[], int[], int) - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesIndexedInts
- get(int[], int, int) - Method in interface org.apache.druid.segment.data.IndexedInts
- get(int[], int, int) - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesIndexedInts
- 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(ListenableFuture<T>, boolean) - Static method in class org.apache.druid.common.guava.FutureUtils
-
Waits for a given future and returns its value, like
future.get()
. - get(String) - Method in class org.apache.druid.guice.NestedDataModule.NestedColumnV4HandlerProvider
- get(String) - Method in class org.apache.druid.guice.NestedDataModule.NestedCommonFormatHandlerProvider
- get(String) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldLambdaBinding
- get(String) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianMapLambdaBinding
- get(String) - Method in class org.apache.druid.math.expr.ApplyFunction.FoldLambdaBinding
- get(String) - Method in class org.apache.druid.math.expr.ApplyFunction.MapLambdaBinding
- get(String) - Method in class org.apache.druid.math.expr.ApplyFunction.SettableLambdaBinding
- get(String) - Method in interface org.apache.druid.math.expr.Expr.ObjectBinding
-
Get value binding for string identifier of
IdentifierExpr
- get(String) - Method in class org.apache.druid.math.expr.InputBindings.BestEffortInputBindings
- get(String) - Method in class org.apache.druid.math.expr.SettableObjectBinding
- get(String) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorInputBindings
- get(String) - Method in interface org.apache.druid.query.lookup.LookupExtractorFactoryContainerProvider
-
Returns a lookup container for the provided lookupName, if it exists.
- get(String) - Method in class org.apache.druid.query.QueryContext
-
Return a value as a generic
Object
, returningnull
if the context value is not set. - get(String) - Method in interface org.apache.druid.segment.DimensionHandlerProvider
- get(String) - Method in class org.apache.druid.segment.Metadata
- get(String) - Method in class org.apache.druid.segment.virtual.SingleInputBindings
- get(String, List<Expr>) - Method in class org.apache.druid.math.expr.ExprMacroTable
-
Returns an expr corresponding to a function call if this table has an entry for
functionName
. - get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
- 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.NilVectorAggregator
- 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.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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantVectorAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleMaxVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleMinVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DoubleSumVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.DoubleFirstLastVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.SingleStringFirstLastDimensionVectorAggregator
-
Doesnt need to handle the null handling because that is taken care of while inserting the value, therefore in replaceWithDefault mode, it is always going to be non-null
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatMaxVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatMinVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FloatSumVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMaxVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongMinVectorAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.LongSumVectorAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
- get(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopVectorAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SingleValueBufferAggregator
- 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(ByteBuffer, int, int) - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
-
Retrieve aggregation state from one of our aggregators.
- get(ResponseContext.Key) - Method in class org.apache.druid.query.context.ResponseContext
- get(ColumnValueSelector<Number>) - Method in interface org.apache.druid.frame.field.NumericFieldWriterFactory
-
Constructs an instance of
NumericFieldWriter
given the column selector - getAbscissa() - Method in class org.apache.druid.collections.spatial.search.PolygonBound
- getAccumulator() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorInputBindings
- getAccumulatorIdentifier() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getAccumulatorType() - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldLambdaBinding
- getAccumulatorType() - Method in class org.apache.druid.math.expr.ApplyFunction.FoldLambdaBinding
- getAccumulatorType() - Method in interface org.apache.druid.math.expr.ApplyFunction.IndexableFoldLambdaBinding
- getActiveTasks() - Method in class org.apache.druid.query.PrioritizedExecutorService
-
Returns the approximate number of tasks being run by the thread pool currently.
- getActualMaxMergingDictionarySize(long, int) - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
-
For unit tests.
- getActualMaxMergingDictionarySize(DruidProcessingConfig) - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- getActualMaxSelectorDictionarySize(DruidProcessingConfig) - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- getActualValue(int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- getActualValue(int, boolean) - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- getAddExtensionsToHadoopContainer() - Method in class org.apache.druid.guice.ExtensionsConfig
- getAdjustedCumulativeRowLength(Memory, long, int) - Static method in class org.apache.druid.frame.read.columnar.FrameColumnReaderUtils
- getAggIndexForOrderBy(OrderByColumnSpec, List<AggregatorFactory>) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- getAggregateMultipleValues() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
- 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
- getAggregations() - Method in class org.apache.druid.query.operator.window.WindowFramedAggregateProcessor
- getAggregator() - Method in class org.apache.druid.query.aggregation.AggregatorAndSize
- getAggregator() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- getAggregatorFactories() - Method in class org.apache.druid.segment.SchemaPayload
- getAggregatorMergeStrategy() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- 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
- getAggsArray() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
- getAggsForRow(int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
- getAllChannels() - Method in class org.apache.druid.frame.processor.OutputChannels
-
Returns all channels.
- 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. - getAllObjects(List<TimelineObjectHolder<VersionType, ObjectType>>) - Static method in class org.apache.druid.timeline.VersionedIntervalTimeline
- getAllowedPropertyPrefixesForHadoop() - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
-
Property prefixes that should be added to the "allowedHadoopPrefix" config for passing down to Hadoop jobs.
- getAllowedProtocols() - Method in class org.apache.druid.data.input.impl.HttpInputSourceConfig
- getAllReadableChannels() - Method in class org.apache.druid.frame.processor.OutputChannels
-
Returns all channels, as readable channels.
- getAllTimelineEntries() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- getAnalysis() - Method in interface org.apache.druid.query.DataSource
-
Get the analysis for a data source
- getAnalysis() - Method in class org.apache.druid.query.FilteredDataSource
- getAnalysis() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- getAnalysis() - Method in class org.apache.druid.query.InlineDataSource
- getAnalysis() - Method in class org.apache.druid.query.JoinDataSource
- getAnalysis() - Method in class org.apache.druid.query.LookupDataSource
- getAnalysis() - Method in class org.apache.druid.query.QueryDataSource
- getAnalysis() - Method in class org.apache.druid.query.TableDataSource
- getAnalysis() - Method in class org.apache.druid.query.UnionDataSource
- getAnalysis() - Method in class org.apache.druid.query.UnnestDataSource
- getAnalysis() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
Returns basic analysis of the inputs to an
Expr
and how they are used - getAnalysisTypes() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- getAndAddLong(long, long) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getAndResetMaxTime() - Method in class org.apache.druid.java.util.emitter.core.ConcurrentTimeCounter
-
Returns the max time
ConcurrentTimeCounter.add(int)
ed since the previous call to this method or since the creation of this object, or null if no times were added. - getAndResetMinTime() - Method in class org.apache.druid.java.util.emitter.core.ConcurrentTimeCounter
-
Returns the min time
ConcurrentTimeCounter.add(int)
ed since the previous call to this method or since the creation of this object, or null if no times were added. - getAndSetLong(long, long) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getAppliedExpression() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
If an expression uses a multi-valued input in a scalar manner, the expression can be automatically transformed to map these values across the expression, applying the original expression to every value.
- getAppliedFoldExpression(String) - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
If an expression uses a multi-valued input in a scalar manner, and the expression contains an accumulator such as for use as part of an aggregator, the expression can be automatically transformed to fold the accumulator across the values of the original expression.
- getApplyFunction(String) - Static method in class org.apache.druid.math.expr.Parser
- 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.
- getArgs() - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- getArgs() - Method in interface org.apache.druid.math.expr.ExprMacroTable.ExprMacroFunctionExpr
- getArray() - Method in class org.apache.druid.query.groupby.ResultRow
-
Get the backing array for this row (not a copy).
- getArray() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getArray() - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getArrayBindings() - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Set of
IdentifierExpr.binding
which are used as array inputs to operators, functions, and apply functions. - getArrayBuffer() - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- getArrayCardinality() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- getArrayDictionary() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getArrayDictionary() - Method in interface org.apache.druid.segment.nested.NestedCommonFormatColumn
- getArrayDictionary() - Method in class org.apache.druid.segment.nested.VariantColumn
- getArrayIndex(Object, int) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- getArrayIndex(Object, int, boolean) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
-
Deprecated.
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianMapFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.FilterFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.FoldFunction
- getArrayInputs(List<Expr>) - Method in interface org.apache.druid.math.expr.ApplyFunction
-
Get list of input arguments which must evaluate to an array
ExprType
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.MapFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.MatchFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayConstructorFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayLengthFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayScalarFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraysFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraySliceFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraysMergeFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.CastFunc
- getArrayInputs(List<Expr>) - Method in interface org.apache.druid.math.expr.Function
-
Given a list of arguments to this
Function
, get the set of arguments that must evaluate to an array value - getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- getArrayInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- getArrayProvider() - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams
- getAsBoolean(String, Object) - Static method in class org.apache.druid.query.QueryContexts
- getAsBoolean(String, Object, boolean) - Static method in class org.apache.druid.query.QueryContexts
-
Get the value of a context value as a
boolean
. - getAsEnum(String, Object, Class<E>) - Static method in class org.apache.druid.query.QueryContexts
- getAsEnum(String, Object, Class<E>, E) - Static method in class org.apache.druid.query.QueryContexts
- getAsFloat(String, Object) - Static method in class org.apache.druid.query.QueryContexts
-
Get the value of a context value as an
Float
. - getAsFloat(String, Object, float) - Static method in class org.apache.druid.query.QueryContexts
- getAsHumanReadableBytes(String, Object, HumanReadableBytes) - Static method in class org.apache.druid.query.QueryContexts
- getAsInt() - Method in class org.apache.druid.segment.RowNumCounter
- getAsInt(String, Object) - Static method in class org.apache.druid.query.QueryContexts
- getAsInt(String, Object, int) - Static method in class org.apache.druid.query.QueryContexts
-
Get the value of a context value as an
int
. - getAsLong() - Method in class org.apache.druid.common.utils.CurrentTimeMillisSupplier
- getAsLong(String, Object) - Static method in class org.apache.druid.query.QueryContexts
- getAsLong(String, Object, long) - Static method in class org.apache.druid.query.QueryContexts
-
Get the value of a context value as an
long
. - getAsMap() - Method in class org.apache.druid.error.ErrorResponse
- getAsString(String, Object, String) - Static method in class org.apache.druid.query.QueryContexts
- getAt(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
- getATN() - Method in class org.apache.druid.math.expr.antlr.ExprLexer
- getATN() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- getAtomicUpdateGroupSize() - Method in class org.apache.druid.segment.ReferenceCountingSegment
- getAtomicUpdateGroupSize() - Method in class org.apache.druid.timeline.DataSegment
- getAtomicUpdateGroupSize() - Method in interface org.apache.druid.timeline.Overshadowable
-
Return the size of atomicUpdateGroup.
- getAtomicUpdateGroupSize() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- getAtomicUpdateGroupSize() - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
Returns the atomic update group size which this segment belongs to.
- getAuditInfo() - Method in class org.apache.druid.audit.AuditEntry
- getAuditTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getAuditTime() - Method in class org.apache.druid.audit.AuditEntry
- getAuthor() - Method in class org.apache.druid.audit.AuditInfo
- 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.frame.segment.columnar.FrameQueryableIndex
- getAvailableDimensions() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getAvailableDimensions() - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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
- getAvailableDimensions() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getAvailableMetrics() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getAvailableMetrics() - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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
- getAvailableMetrics() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getAvailableProcessors() - Method in class org.apache.druid.utils.RuntimeInfo
- getBase() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getBase() - Method in class org.apache.druid.query.FilteredDataSource
- getBase() - Method in class org.apache.druid.query.rowsandcols.LazilyDecoratedRowsAndColumns
- getBase() - Method in class org.apache.druid.query.UnnestDataSource
- getBaseAdapter() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getBaseColumn() - Method in class org.apache.druid.query.rowsandcols.concrete.ColumnHolderRACColumn
- 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.
- getBaseDir() - Method in class org.apache.druid.data.input.impl.LocalInputSource
- getBaseDir() - Method in class org.apache.druid.storage.StorageConfig
- getBaseExpressions() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
- getBaseFilter() - Method in class org.apache.druid.segment.filter.NotFilter
- getBaseInputEntity() - Method in class org.apache.druid.data.input.BytesCountingInputEntity
- getBaseObject() - Method in class org.apache.druid.query.MetricValueExtractor
- getBaseObject() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
- getBasePath() - Method in interface org.apache.druid.storage.ExportStorageProvider
-
Return a URI representation of the base path.
- getBasePath() - Method in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- getBasePath() - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
- getBaseQuery() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
Returns the bottom-most (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.frame.segment.FrameFilteredOffset
- 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
- getBaseRow() - Method in class org.apache.druid.segment.transform.TransformedInputRow
- getBaseSegment() - Method in class org.apache.druid.segment.ReferenceCountingSegment
- getBaseTableDataSource() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
If
DataSourceAnalysis.getBaseDataSource()
is aTableDataSource
, returns it. - getBaseTableFilter() - Method in class org.apache.druid.segment.join.filter.JoinFilterSplit
- getBaseUnionDataSource() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
If
DataSourceAnalysis.getBaseDataSource()
is aUnionDataSource
, returns it. - getBasicAuthentication() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getBatchFillingTimeCounter() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getBatchingStrategy() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getBatchQueueSizeLimit() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getBatchSize() - Method in class org.apache.druid.query.scan.ScanQuery
- getBinaryVersion() - Method in class org.apache.druid.timeline.DataSegment
- getBindingIfIdentifier() - Method in interface org.apache.druid.math.expr.Expr
-
Returns the string key to use to get a value from
Expr.ObjectBinding
of anIdentifierExpr
, else null. - getBindings() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory.FactorizePlan
- 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() - Method in interface org.apache.druid.query.filter.FilterBundle.IndexBundle
- getBitmap() - Method in class org.apache.druid.query.filter.FilterBundle.SimpleIndexBundle
- getBitmap(int) - Method in class org.apache.druid.segment.index.IndexedStringDictionaryEncodedStringValueIndex
- getBitmap(int) - Method in interface org.apache.druid.segment.index.semantic.DictionaryEncodedValueIndex
-
Get the
ImmutableBitmap
for dictionary id of the underlying dictionary - getBitmap(int) - Method in class org.apache.druid.segment.index.semantic.ValueSetIndexes.BaseValueSetIndexesFromIterable
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.query.filter.EqualityFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in interface org.apache.druid.query.filter.Filter
-
Returns a
BitmapColumnIndex
if this filter supports using a bitmap index for filtering for the given inputColumnIndexSelector
. - getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.query.filter.InDimFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.query.filter.NullFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.query.filter.RangeFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.query.filter.TypedInFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.AndFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.BoundFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.ColumnComparisonFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.DimensionPredicateFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.ExpressionFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.FalseFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.IsBooleanFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.LikeFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.NotFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.OrFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.SelectorFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.SpatialFilter
- getBitmapColumnIndex(ColumnIndexSelector) - Method in class org.apache.druid.segment.filter.TrueFilter
- getBitmapFactory() - Method in class org.apache.druid.collections.spatial.ImmutableFloatNode
- getBitmapFactory() - Method in interface 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.ColumnIndexSelector
- getBitmapFactory() - Method in class org.apache.druid.segment.ColumnSelectorColumnIndexSelector
- 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
- getBitmapFactory() - Method in class org.apache.druid.segment.index.IndexedStringDictionaryEncodedStringValueIndex
- getBitmapFactory() - Method in interface org.apache.druid.segment.index.semantic.DictionaryEncodedValueIndex
- getBitmapFactoryForDimensions() - Method in class org.apache.druid.frame.segment.columnar.FrameQueryableIndex
- getBitmapFactoryForDimensions() - Method in interface org.apache.druid.segment.QueryableIndex
- getBitmapFactoryForDimensions() - Method in class org.apache.druid.segment.SimpleQueryableIndex
- getBitmapIndexes() - Method in class org.apache.druid.segment.MMappedIndex
- getBitmapIterable() - Method in class org.apache.druid.segment.index.SimpleImmutableBitmapDelegatingIterableIndex
- getBitmapIterable(boolean) - Method in class org.apache.druid.segment.index.SimpleImmutableBitmapIterableIndex
- getBitmapSerdeFactory() - Method in class org.apache.druid.segment.IndexSpec
- getBitmapSerdeFactory() - Method in class org.apache.druid.segment.nested.NestedDataColumnMetadata
- 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
- getBitmapSerdeFactory() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- getBitmapSerdeFactory() - Method in class org.apache.druid.segment.serde.NullColumnPartSerde
-
Deprecated.
- 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
- 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
- getBoolean() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getBoolean(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getBoolean(String) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
Boolean
, returning {@link null} if the context value is not set. - getBoolean(String, boolean) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
boolean
, returning the default value if the context value is not set. - getBooleanArray(boolean[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getBooleanArray(long, boolean[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getBootId() - Method in class org.apache.druid.java.util.metrics.ProcFsReader
-
Reads the boot ID from the boot_id path, which is just a UUID.
- getBossPoolSize() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- 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
- getBrokerServiceName() - Method in class org.apache.druid.query.QueryContext
- getBucket() - Method in class org.apache.druid.data.input.impl.CloudObjectLocation
- getBucketByCount() - Method in class org.apache.druid.frame.key.ClusterBy
-
How many fields from
ClusterBy.getColumns()
comprise the "bucket key". - getBucketId() - Method in interface org.apache.druid.timeline.partition.BucketNumberedShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- getBucketId() - Method in interface org.apache.druid.timeline.partition.BuildingShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- getBucketId() - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- getBucketIterable() - Method in class org.apache.druid.query.vector.VectorCursorGranularizer
- getBuckets() - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- getBucketSize() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- getBuffer() - Method in class org.apache.druid.data.input.impl.ByteEntity
-
Return the buffer backing this entity.
- getBuffer() - Method in class org.apache.druid.utils.CircularBuffer
- 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
- getBufferSize() - Method in class org.apache.druid.query.DruidProcessingBufferConfig
- getBufferSize() - Method in class org.apache.druid.query.operator.join.JoinConfig
- getBuffersToEmit() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getBuffersToReuse() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getBuilder() - Method in class org.apache.druid.java.util.http.client.response.StatusResponseHolder
- getBuildTimeNs() - Method in class org.apache.druid.query.filter.FilterBundle.IndexBundleInfo
- getBySegmentResultType() - Method in class org.apache.druid.query.QueryToolChest
- getByte() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getByte(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getByteArray(byte[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getByteArray(long, byte[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getByteBuf(ByteOrder) - Static method in class org.apache.druid.segment.CompressedPools
- getByteBuffer() - Method in class org.apache.druid.segment.data.SafeWritableBase
- getByteBuffer(int) - Method in class org.apache.druid.segment.data.GenericIndexed.BufferIndexed
-
Like
GenericIndexed.BufferIndexed.get(int)
, but returns aByteBuffer
instead of using theObjectStrategy
. - getByteCount() - Method in class org.apache.druid.java.util.http.client.response.SequenceInputStreamResponseHandler
- getByteOrder() - Method in class org.apache.druid.segment.nested.NestedDataColumnMetadata
- 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
- getByteOrder() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- getBytes() - Method in class org.apache.druid.java.util.common.HumanReadableBytes
- getBytesAdded() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
- getBytesInInt() - Method in class org.apache.druid.java.util.common.HumanReadableBytes
- getBytesInMemory() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- getBytesInMemory() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
- getBytesRead() - Method in class org.apache.druid.frame.file.FrameFilePartialFetch
-
Number of bytes read so far by this request.
- getByteValue() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- getByteValue() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.TypeSet
- 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.frame.util.SettableLongVirtualColumn
- getCacheKey() - Method in interface org.apache.druid.java.util.common.Cacheable
-
Get a byte array used as a cache key.
- getCacheKey() - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- getCacheKey() - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- getCacheKey() - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- getCacheKey() - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- getCacheKey() - Method in enum org.apache.druid.java.util.common.StringEncoding
- getCacheKey() - Method in interface org.apache.druid.math.expr.Expr
- 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.ExpressionLambdaAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- 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.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
- getCacheKey() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- getCacheKey() - Method in interface org.apache.druid.query.DataSource
-
Compute a cache key prefix for a data source.
- 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.ArrayContainsElementFilter
- 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.EqualityFilter
- 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.IsBooleanDimFilter
- 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.NullFilter
- getCacheKey() - Method in class org.apache.druid.query.filter.OrDimFilter
- getCacheKey() - Method in class org.apache.druid.query.filter.RangeFilter
- 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.filter.TypedInFilter
- getCacheKey() - Method in class org.apache.druid.query.FilteredDataSource
- getCacheKey() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- 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.InlineDataSource
- getCacheKey() - Method in class org.apache.druid.query.JoinDataSource
- getCacheKey() - Method in class org.apache.druid.query.lookup.ImmutableLookupMap.ImmutableLookupExtractor
- 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.LookupDataSource
- getCacheKey() - Method in class org.apache.druid.query.metadata.metadata.AllColumnIncluderator
- 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.NaturalComparator
- 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.QueryDataSource
- 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 class org.apache.druid.query.search.SearchSortSpec
- getCacheKey() - Method in class org.apache.druid.query.TableDataSource
- 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.query.UnionDataSource
- getCacheKey() - Method in class org.apache.druid.query.UnnestDataSource
- getCacheKey() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- getCacheKey() - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- getCacheKey() - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- getCacheKey() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- 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(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
- 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.
- getCancellationGizmo() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence
- getCapabilities() - Method in class org.apache.druid.frame.read.columnar.ColumnPlus
- getCapabilities() - Method in interface org.apache.druid.segment.column.ColumnHolder
- getCapabilities() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
- 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
- getCapabilitiesBuilder() - Method in class org.apache.druid.segment.column.ColumnBuilder
- getCapacity() - Method in class org.apache.druid.segment.data.SafeWritableBase
- getCardinality() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- getCardinality() - Method in class org.apache.druid.query.topn.TopNParams
- getCardinality() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getCardinality() - Method in class org.apache.druid.segment.AutoTypeColumnMerger.ArrayDictionaryMergingIterator
- getCardinality() - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
- getCardinality() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- getCardinality() - Method in interface org.apache.druid.segment.data.DictionaryWriter
- getCardinality() - Method in class org.apache.druid.segment.data.EncodedStringDictionaryWriter
- getCardinality() - Method in class org.apache.druid.segment.data.FixedIndexedWriter
- getCardinality() - Method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
- getCardinality() - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- getCardinality() - Method in class org.apache.druid.segment.data.GenericIndexedWriter
- getCardinality() - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- getCardinality() - Method in class org.apache.druid.segment.DictionaryMergingIterator
- 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() - Method in class org.apache.druid.segment.index.IndexedStringDictionaryEncodedStringValueIndex
- getCardinality() - Method in interface org.apache.druid.segment.index.semantic.DictionaryEncodedValueIndex
-
Get the cardinality of the underlying value dictionary
- getCardinality() - Method in class org.apache.druid.segment.LongDimensionIndexer
- getCardinality() - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- getCardinality() - Method in class org.apache.druid.segment.nested.ValueDictionary
- getCardinality() - Method in class org.apache.druid.segment.nested.VariantColumn
- getCardinality() - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- getCardinality() - Method in class org.apache.druid.segment.SimpleDictionaryMergingIterator
- 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(DimensionSelector) - Method in class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
- getCardinality(Selector) - Method in class org.apache.druid.query.topn.types.NullableNumericTopNColumnAggregatesProcessor
- getCardinality(ValueSelectorType) - Method in interface org.apache.druid.query.topn.types.TopNColumnAggregatesProcessor
-
Get value cardinality of underlying
ColumnValueSelector
- getCardinalityForArrayAggregation(GroupByQueryConfig, GroupByQuery, StorageAdapter, ByteBuffer) - Static method in class org.apache.druid.query.groupby.GroupingEngine
-
Returns the cardinality of array needed to do array-based aggregation, or -1 if array-based aggregation is impossible.
- getCastToType() - Method in class org.apache.druid.segment.AutoTypeColumnSchema
- getCategory() - Method in exception org.apache.druid.error.DruidException
- getCauseOfType(Throwable, Class<T>) - Static method in class org.apache.druid.utils.Throwables
-
searches for a throwable in the cause chain that is of same type as {@param searchFor}.
- getCell(int) - Method in class org.apache.druid.segment.serde.cell.CellReader
- getChannelsForPartition(int) - Method in class org.apache.druid.frame.processor.OutputChannels
-
Returns channels for which
OutputChannel.getPartitionNumber()
returnspartitionNumber
. - getChar() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getChar(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getCharArray(char[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getCharArray(long, char[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getCharsFromUtf8(long, int, Appendable) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getCharsFromUtf8(long, int, StringBuilder) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getChildren() - Method in class org.apache.druid.collections.spatial.ImmutableFloatNode
- getChildren() - Method in class org.apache.druid.collections.spatial.ImmutableFloatPoint
- getChildren() - Method in interface org.apache.druid.collections.spatial.ImmutableNode
- 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.FilteredDataSource
- getChildren() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- 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
- getChildren() - Method in class org.apache.druid.query.UnnestDataSource
- getChunk() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline.PartitionChunkEntry
- getChunk(int) - Method in class org.apache.druid.timeline.partition.PartitionHolder
- getChunkNumber() - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- getChunkNumber() - Method in class org.apache.druid.timeline.partition.LinearPartitionChunk
- getChunkNumber() - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- getChunkNumber() - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- getChunkNumber() - Method in interface org.apache.druid.timeline.partition.PartitionChunk
-
Returns the partition chunk number of this PartitionChunk.
- getChunkNumber() - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- getChunkNumber() - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- getChunkNumber() - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- getClassLoaderForExtension(File, boolean) - Method in class org.apache.druid.guice.ExtensionsLoader
- getClazz() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexColumn
- getClazz() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn
- getClazz() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn
- getClazz() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn
- 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
- getClazz() - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
- getCloseCount() - Method in class org.apache.druid.java.util.common.guava.ExplodingSequence
- 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
- getCloudStoragePath() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- getColumn() - Method in class org.apache.druid.frame.read.columnar.ColumnPlus
- getColumn() - Method in exception org.apache.druid.frame.write.InvalidFieldException
- getColumn() - Method in exception org.apache.druid.frame.write.InvalidNullByteException
- getColumn() - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- getColumn() - Method in class org.apache.druid.query.filter.EqualityFilter
- getColumn() - Method in class org.apache.druid.query.filter.NullFilter
- getColumn() - Method in class org.apache.druid.query.filter.RangeFilter
- getColumn() - Method in class org.apache.druid.query.filter.TypedInFilter
- getColumn() - Method in class org.apache.druid.query.operator.ColumnWithDirection
- getColumn() - Method in interface org.apache.druid.segment.column.ColumnHolder
- getColumn(String) - Method in class org.apache.druid.segment.ColumnCache
- getColumnCapabilities() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- 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.LongDimensionIndexer
- getColumnCapabilities() - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- getColumnCapabilities() - Method in class org.apache.druid.segment.StringDimensionIndexer
- getColumnCapabilities(String) - Method in class org.apache.druid.frame.processor.MultiColumnSelectorFactory
- getColumnCapabilities(String) - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getColumnCapabilities(String) - Method in class org.apache.druid.frame.segment.row.FrameColumnSelectorFactory
- getColumnCapabilities(String) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultColumnSelectorFactoryMaker.ColumnAccessorBasedColumnSelectorFactory
- getColumnCapabilities(String) - Method in class org.apache.druid.query.scan.SettableCursorColumnSelectorFactory
-
Return column capabilities from the signature.
- 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.ColumnSelector
- getColumnCapabilities(String) - Method in class org.apache.druid.segment.ColumnSelectorColumnIndexSelector
- getColumnCapabilities(String) - Method in interface org.apache.druid.segment.ColumnSelectorFactory
-
Returns capabilities of a particular column, if known.
- getColumnCapabilities(String) - Method in class org.apache.druid.segment.FilteredStorageAdapter
- getColumnCapabilities(String) - 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(String) - Method in interface org.apache.druid.segment.QueryableIndex
- getColumnCapabilities(String) - Method in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
- getColumnCapabilities(String) - 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(String) - Method in class org.apache.druid.segment.UnnestStorageAdapter
- 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.VirtualizedColumnInspector
- getColumnCapabilitiesWithFallback(ColumnInspector, String) - Method in class org.apache.druid.segment.VirtualColumns
-
Get capabilities for the column "columnName".
- getColumnExceptionMessages() - Method in exception org.apache.druid.java.util.common.parsers.UnparseableColumnsParseException
- getColumnFormat() - Method in interface org.apache.druid.segment.column.ColumnHolder
- getColumnFormat(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- getColumnFormats() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- getColumnFromJoinIfExists(String) - Method in class org.apache.druid.segment.join.filter.JoinableClauses
- getColumnHandler(String) - Method in class org.apache.druid.segment.column.CapabilitiesBasedFormat
- getColumnHandler(String) - Method in interface org.apache.druid.segment.column.ColumnFormat
- getColumnHandler(String) - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumn.Format
- getColumnHandler(String) - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde.NestedColumnFormatV4
- getColumnHolder(String) - Method in class org.apache.druid.frame.segment.columnar.FrameQueryableIndex
- getColumnHolder(String) - Method in class org.apache.druid.segment.ColumnCache
- getColumnHolder(String) - Method in interface org.apache.druid.segment.ColumnSelector
- getColumnHolder(String) - Method in class org.apache.druid.segment.ColumnSelectorColumnIndexSelector
- getColumnHolder(String) - Method in class org.apache.druid.segment.DeprecatedQueryableIndexColumnSelector
-
Deprecated.
- getColumnHolder(String) - Method in interface org.apache.druid.segment.QueryableIndex
- getColumnHolder(String) - Method in class org.apache.druid.segment.SimpleQueryableIndex
- getColumnHolder(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getColumnHolder(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Get a
ColumnHolder
for a nested field column to retrieve metadata, the column itself, or indexes. - getColumnIndexSupplier(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getColumnIndexSupplier(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Make a
ColumnIndexSupplier
for a nested field column - getColumnName() - Method in exception org.apache.druid.frame.write.UnsupportedColumnTypeException
- getColumnName() - Method in class org.apache.druid.query.scan.ScanQuery.OrderBy
- getColumnName() - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- getColumnName() - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- getColumnName() - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- getColumnName() - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- getColumnName() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- 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.frame.segment.columnar.FrameQueryableIndex
- getColumnNames() - Method in class org.apache.druid.query.InlineDataSource
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.AppendableMapOfColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.ConcatRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.concrete.ColumnBasedFrameRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.concrete.QueryableIndexRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.concrete.RowBasedFrameRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.EmptyRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.LazilyDecoratedRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.LimitedRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.RearrangedRowsAndColumns
- getColumnNames() - Method in interface org.apache.druid.query.rowsandcols.RowsAndColumns
-
The set of column names available from the RowsAndColumns
- getColumnNames() - Method in class org.apache.druid.query.rowsandcols.StorageAdapterRowsAndColumns
- 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 class org.apache.druid.segment.incremental.IncrementalIndex
- getColumnNames() - Method in interface org.apache.druid.segment.QueryableIndex
- getColumnNames() - Method in class org.apache.druid.segment.SimpleQueryableIndex
- getColumnNames() - Method in class org.apache.druid.segment.VirtualColumns
- getColumns() - Method in class org.apache.druid.data.input.impl.CSVParseSpec
- getColumns() - Method in class org.apache.druid.data.input.impl.DelimitedParseSpec
- getColumns() - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- getColumns() - Method in class org.apache.druid.data.input.impl.RegexInputFormat
- getColumns() - Method in class org.apache.druid.data.input.impl.RegexParseSpec
- getColumns() - Method in class org.apache.druid.frame.key.ClusterBy
-
The columns that comprise this key, in order.
- 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
- getColumns() - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- getColumnSchema(String) - Method in class org.apache.druid.segment.column.CapabilitiesBasedFormat
- getColumnSchema(String) - Method in interface org.apache.druid.segment.column.ColumnFormat
- getColumnSchema(String) - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumn.Format
- getColumnSchema(String) - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde.NestedColumnFormatV4
- getColumnSchemas() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
- getColumnSelectorFactory() - Method in class org.apache.druid.frame.segment.columnar.FrameVectorCursor
- getColumnSelectorFactory() - Method in class org.apache.druid.frame.segment.FrameCursor
- 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 class org.apache.druid.segment.UnnestColumnValueSelectorCursor
- getColumnSelectorFactory() - Method in class org.apache.druid.segment.UnnestDimensionCursor
- 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
- getColumnsFilter() - Method in class org.apache.druid.data.input.InputRowSchema
-
A
ColumnsFilter
that can filter down the list of columns that must be read after flattening. - getColumnType() - Method in class org.apache.druid.data.input.impl.DimensionSchema
- getColumnType() - Method in class org.apache.druid.data.input.impl.DoubleDimensionSchema
- getColumnType() - Method in class org.apache.druid.data.input.impl.FloatDimensionSchema
- getColumnType() - Method in class org.apache.druid.data.input.impl.LongDimensionSchema
- getColumnType() - Method in class org.apache.druid.data.input.impl.NewSpatialDimensionSchema
- getColumnType() - Method in class org.apache.druid.data.input.impl.StringDimensionSchema
- getColumnType() - Method in enum org.apache.druid.data.input.impl.systemfield.SystemField
-
Type of this system field.
- getColumnType() - Method in exception org.apache.druid.frame.write.UnsupportedColumnTypeException
- getColumnType() - Method in class org.apache.druid.segment.AutoTypeColumnSchema
- getColumnType() - Method in class org.apache.druid.segment.NestedDataColumnSchema
- 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. - 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. - getColumnTypes() - Method in class org.apache.druid.query.InlineDataSource
- getColumnTypes() - Method in class org.apache.druid.query.scan.ScanQuery
- getColumnTypes() - Method in class org.apache.druid.segment.column.RowSignature
-
Returns the column types in the order they are in.
- getColumnTypes(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getColumnTypes(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Get all
ColumnType
for the nested field column - getColumnValues() - Method in class org.apache.druid.segment.join.Joinable.ColumnValuesWithUniqueFlag
- getColumnValueSelector(Memory, ReadableFieldPointer, byte) - Method in class org.apache.druid.frame.field.DoubleFieldReader
- getColumnValueSelector(Memory, ReadableFieldPointer, byte) - Method in class org.apache.druid.frame.field.FloatFieldReader
- getColumnValueSelector(Memory, ReadableFieldPointer, byte) - Method in class org.apache.druid.frame.field.LongFieldReader
- getColumnValueSelector(Memory, ReadableFieldPointer, byte) - Method in class org.apache.druid.frame.field.NumericFieldReader
-
Creates a column value selector for the element written at fieldPointer's position in the memory.
- getCombinedParseException(InputRow, List<String>, List<String>) - Static method in class org.apache.druid.segment.incremental.IncrementalIndex
- getCombineExpressionString() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- 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.ExpressionLambdaAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- 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.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
- getCombiningFactory() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- getComment() - Method in class org.apache.druid.audit.AuditInfo
- getComparator() - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader.NumericArrayFrameColumn
- 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.ExpressionLambdaAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- getComparator() - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- 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
- getCompareExpressionString() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getCompilePath(String) - Static method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- getComplex(String) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Get an
TypeStrategy
registered to someTypeSignature.getComplexTypeName()
. - getComplexTypeName() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Deprecated.
- getComplexTypeName() - Method in class org.apache.druid.segment.column.BaseTypeSignature
- getComplexTypeName() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- getComplexTypeName() - Method in interface org.apache.druid.segment.column.TypeSignature
-
Type name of 'complex' types (
ValueType.COMPLEX
,ExprType.COMPLEX
), which are 'registered' by their name, acting as a key to get the correct set of serialization, deserialization, and other type specific handling facilties. - getComponent() - Method in class org.apache.druid.segment.EncodedKeyComponent
-
Encoded dimension value(s) to be used as a component for a row key.
- getCompressedBlobsFileName(String) - Static method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSerializer
- getCompressedOffsetsFileName(String) - Static method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSerializer
- getCompressionCodec() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- getCompressor() - Method in enum org.apache.druid.segment.data.CompressionStrategy
- 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 interface org.apache.druid.metadata.DynamicConfigProvider
- getConfig() - Method in class org.apache.druid.metadata.EnvironmentVariableDynamicConfigProvider
- getConfig() - Method in class org.apache.druid.metadata.MapStringDynamicConfigProvider
- getConfig() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
- getConfigManager(MetadataStorageConnector, Supplier<MetadataStorageTablesConfig>, Supplier<ConfigManagerConfig>, Lifecycle) - Method in class org.apache.druid.guice.JacksonConfigManagerModule
- getConfigTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getConfiguredSystemFields() - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- getConfiguredSystemFields() - Method in class org.apache.druid.data.input.impl.HttpInputSource
- getConfiguredSystemFields() - Method in class org.apache.druid.data.input.impl.LocalInputSource
- getConfiguredSystemFields() - Method in interface org.apache.druid.data.input.impl.systemfield.SystemFieldInputSource
-
System fields that this input source is configured to return.
- getConnectURI() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- getConstant() - Static method in class org.apache.druid.segment.column.SimpleColumnIndexCapabilities
-
ColumnIndexCapabilities
to use for constant values (including 'null' values for 'missing' columns) - getConstantValue() - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
- getConstantValue() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getConstantValue() - Method in class org.apache.druid.segment.IndexableAdapter.NestedColumnMergable
- getContainer() - Method in class org.apache.druid.segment.Metadata
- getContent() - Method in class org.apache.druid.java.util.http.client.Request
- getContent() - Method in class org.apache.druid.java.util.http.client.response.BytesFullResponseHolder
- getContent() - Method in class org.apache.druid.java.util.http.client.response.FullResponseHolder
-
Get the data.
- getContent() - Method in class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHolder
- getContent() - Method in class org.apache.druid.java.util.http.client.response.StatusResponseHolder
- getContent() - Method in class org.apache.druid.java.util.http.client.response.StringFullResponseHolder
- getContentEncoding() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getContext() - Method in exception org.apache.druid.error.DruidException
- 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
-
Returns the context as an (immutable) map.
- getContext() - Method in class org.apache.druid.query.select.SelectQuery
-
Deprecated.
- getContextBoolean(String, boolean) - Method in interface org.apache.druid.query.Query
-
Deprecated.use
queryContext().getBoolean()
instead. - getContextHumanReadableBytes(String, HumanReadableBytes) - Method in interface org.apache.druid.query.Query
-
Deprecated.use
queryContext().getContextHumanReadableBytes()
instead. - getContextSortByDimsFirst() - Method in class org.apache.druid.query.groupby.GroupByQuery
- getContextValue(String) - Method in exception org.apache.druid.error.DruidException
- getContextValue(String) - Method in interface org.apache.druid.query.Query
-
Deprecated.use
queryContext().get<Type>()
instead - getControllerDirectory(String) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
- 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.ImmutableFloatPoint
- 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
- getCpuNanos() - Method in class org.apache.druid.query.context.ResponseContext
- getCpuSetCpus() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuSet.CpuSetMetric
- getCpuSetMems() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuSet.CpuSetMetric
- getCreatedTime() - Method in class org.apache.druid.indexer.TaskInfo
- getCreatedTime() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getCreatedTime() - Method in class org.apache.druid.java.util.emitter.service.AlertEvent
- getCreatedTime() - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- getCumulativeOffset() - Method in class org.apache.druid.segment.data.SafeWritableBase
- getCumulativeOffset(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getCumulativeRowLength(Memory, long, int) - Static method in class org.apache.druid.frame.read.columnar.FrameColumnReaderUtils
-
Returns cumulative row length, if the row is not null itself, or -(cumulative row length) - 1 if the row is null itself.
- getCurrent() - Method in class org.apache.druid.query.lookup.LookupsState
- getCurrentBlockNumber() - Method in class org.apache.druid.segment.data.CompressedBlockReader
-
Get current block number of data loaded in
CompressedBlockReader.decompressedDataBuffer
- getCurrentProcessId() - Static method in class org.apache.druid.java.util.metrics.SigarUtil
- getCurrentRow() - Method in class org.apache.druid.frame.segment.FrameCursor
-
Returns the current row number.
- getCurrentThreadCpuTime() - Static method in class org.apache.druid.utils.JvmUtils
-
Returns the total CPU time for current thread.
- getCurrentVectorId() - Method in interface org.apache.druid.math.expr.Expr.VectorInputBinding
-
Returns an integer that uniquely identifies the current position of the underlying vector offset, if this binding is backed by a segment.
- getCurrentVectorId() - Method in class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- getCurrentVectorSize() - Method in class org.apache.druid.frame.segment.columnar.FrameVectorCursor
- getCurrentVectorSize() - Method in interface org.apache.druid.math.expr.Expr.VectorInputBinding
- getCurrentVectorSize() - Method in class org.apache.druid.query.filter.vector.BaseVectorValueMatcher
- getCurrentVectorSize() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.MultiValueStringVectorObjectSelector
- getCurrentVectorSize() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringMultiValueDimensionVectorSelector
- getCurrentVectorSize() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringSingleValueDimensionVectorSelector
- getCurrentVectorSize() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringVectorObjectSelector
- getCurrentVectorSize() - Method in class org.apache.druid.segment.nested.VariantColumn.VariantVectorObjectSelector
- 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.ExpressionVectorInputBinding
- getCurrentVectorSize() - Method in class org.apache.druid.segment.virtual.ExpressionVectorObjectSelector
- getCurrentVectorSize() - Method in class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
- getCurrentVectorSize() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldVectorObjectSelector
- getCurrentVectorSize() - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector
- getCurrOffset() - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- getCursor() - Method in class org.apache.druid.query.topn.TopNParams
- getCursorFromIterable(Iterable<Object[]>, RowSignature) - Static method in class org.apache.druid.query.IterableRowsCursorHelper
-
Creates a cursor that iterates over all the rows generated by the iterable.
- getCursorFromSequence(Sequence<Object[]>, RowSignature) - Static method in class org.apache.druid.query.IterableRowsCursorHelper
-
Creates a cursor that iterates over all the rows generated by the sequence.
- getCursorFromYielder(Yielder<Object[]>, RowSignature) - Static method in class org.apache.druid.query.IterableRowsCursorHelper
- getData() - Method in class org.apache.druid.collections.spatial.ImmutableFloatNode
- getData() - Method in interface org.apache.druid.collections.spatial.ImmutableNode
- getData() - Method in class org.apache.druid.data.input.impl.InlineInputSource
- getData() - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue.ObjectContainer
- getDataInterval() - Method in class org.apache.druid.frame.segment.columnar.FrameQueryableIndex
- getDataInterval() - Method in class org.apache.druid.frame.segment.FrameSegment
- getDataInterval() - Method in class org.apache.druid.segment.ArrayListSegment
- 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 interface org.apache.druid.segment.Segment
- getDataInterval() - Method in class org.apache.druid.segment.SimpleQueryableIndex
- getDataInterval() - Method in class org.apache.druid.segment.WrappedSegmentReference
- getDataMap() - Method in class org.apache.druid.java.util.emitter.service.AlertEvent
- getDataSegment() - Method in class org.apache.druid.segment.DataSegmentWithMetadata
- getDataSegment() - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- getDataSource() - Method in class org.apache.druid.indexer.TaskInfo
- getDataSource() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getDataSource() - Method in class org.apache.druid.query.BaseQuery
- 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.
- getDataSource() - Method in class org.apache.druid.timeline.DataSegment
-
Get dataSource
- getDataSource() - Method in class org.apache.druid.timeline.SegmentId
- getDataSources() - Method in class org.apache.druid.query.UnionDataSource
- getDataSourcesAsTableDataSources() - Method in class org.apache.druid.query.UnionDataSource
-
Asserts that the children of the union are all table data sources
- getDataSourceTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getDateTime(Integer[]) - Method in enum org.apache.druid.java.util.common.granularity.GranularityType
- getDateTimeZone(String) - Static method in class org.apache.druid.java.util.common.parsers.ParserUtils
- getDbcpProperties() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- getDecompressedDataBuffer() - Method in class org.apache.druid.segment.data.CompressedBlockReader
-
Current decompressed data buffer of the data located in
CompressedBlockReader.currentBlockNumber
- getDecompressor() - Method in enum org.apache.druid.segment.data.CompressionStrategy
- getDefault() - Static method in class org.apache.druid.hll.HyperLogLogHash
- getDefaultAnalysisTypes() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryConfig
- getDefaultBatchSizeAndLimit(long) - Static method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getDefaultColumnName(int) - Static method in class org.apache.druid.java.util.common.parsers.ParserUtils
-
Return a function to generate default column names.
- getDefaultDelimiter() - Method in enum org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser.FlatTextFormat
- getDefaultFormat() - Method in enum org.apache.druid.java.util.common.granularity.GranularityType
- getDefaultGranularity() - Method in enum org.apache.druid.java.util.common.granularity.GranularityType
- getDefaultHistory() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryConfig
- getDefaultMaxBytesInMemory() - Method in interface org.apache.druid.segment.incremental.AppendableIndexSpec
- getDefaultMaxBytesInMemory() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex.Spec
- getDefaultOnDiskStorage() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
-
Mirror maxOnDiskStorage if defaultOnDiskStorage's default is not overridden by cluster operator.
- getDefaultSchemaForBuiltInType(String, TypeSignature<ValueType>) - Static method in class org.apache.druid.data.input.impl.DimensionSchema
- getDefaultSchemas(List<String>) - Static method in class org.apache.druid.data.input.impl.DimensionsSpec
- getDefaultSchemas(List<String>, DimensionSchema.MultiValueHandling) - Static method in class org.apache.druid.data.input.impl.DimensionsSpec
- getDefaultStorageDir(DataSegment, boolean) - Static method in interface org.apache.druid.segment.loading.DataSegmentPusher
- getDefaultStorageDirWithExistingUniquePath(DataSegment, String) - Static method in interface org.apache.druid.segment.loading.DataSegmentPusher
- getDefaultTimeout() - Method in class org.apache.druid.query.QueryContext
- 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.lookup.RegisteredLookupExtractionFn
-
Return the equivalent
LookupExtractionFn
, withLookupExtractor
resolved. - getDelegate() - Method in class org.apache.druid.query.topn.InvertedTopNMetricSpec
- getDelegate() - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- getDelegates() - Method in class org.apache.druid.data.input.impl.CombiningInputSource
- getDelimiter() - Method in class org.apache.druid.data.input.impl.CsvInputFormat
- getDelimiter() - Method in class org.apache.druid.data.input.impl.DelimitedParseSpec
- getDelimiter() - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- getDelta(long[], int, int[], int, int, int, long) - Method in interface org.apache.druid.segment.data.VSizeLongSerde.LongDeserializer
-
Unpack a non-contiguous vector of long values at the specified indexes and adjust them by the supplied delta base value.
- getDelta(long[], int, int, int, long) - Method in interface org.apache.druid.segment.data.VSizeLongSerde.LongDeserializer
-
Unpack a contiguous vector of long values at the specified start index of length and adjust them by the supplied delta base value.
- 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
- getDescription() - Method in class org.apache.druid.java.util.emitter.service.AlertEvent
- getDescriptor() - Method in class org.apache.druid.query.spec.SpecificSegmentSpec
- getDescriptorIteratorForPrefixes(List<URI>) - Method in interface org.apache.druid.data.input.impl.CloudObjectSplitWidget
-
Iterator of descriptors that match a list of prefixes.
- getDescriptors() - Method in class org.apache.druid.query.spec.MultipleSpecificSegmentSpec
- getDeserializer() - Method in interface org.apache.druid.segment.serde.ColumnPartSerde
-
Returns a Deserializer to read a column from a segment.
- 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
- getDeserializer() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- getDeserializer() - Method in class org.apache.druid.segment.serde.NullColumnPartSerde
- getDeserializer(int, ByteBuffer, int) - Static method in class org.apache.druid.segment.data.VSizeLongSerde
- getDetails() - Method in class org.apache.druid.segment.incremental.ParseExceptionReport
- getDictionary() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
-
Return the dictionary of this KeySerde.
- getDictionary() - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- getDictionaryMergingComparator() - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- getDictionaryMergingComparator() - Method in class org.apache.druid.segment.StringDimensionMergerV9
- 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() - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- getDimension() - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- getDimension() - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- getDimension(String) - Method in class org.apache.druid.data.input.ListBasedInputRow
- getDimension(String) - Method in class org.apache.druid.data.input.MapBasedRow
- getDimension(String) - Method in interface org.apache.druid.data.input.Row
-
Returns the list of dimension values for the given column name.
- getDimension(String) - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent.Builder
- getDimension(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- getDimension(String) - Method in class org.apache.druid.segment.transform.TransformedInputRow
- getDimensionCardinality(String) - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getDimensionCardinality(String) - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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 a column, or
DimensionDictionarySelector.CARDINALITY_UNKNOWN
if unknown. - getDimensionCardinality(String) - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getDimensionComparator() - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- getDimensionCompression() - Method in class org.apache.druid.segment.IndexSpec
- getDimensionExclusions() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- getDimensionHandler() - Method in class org.apache.druid.data.input.impl.DimensionSchema
- getDimensionHandler() - Method in class org.apache.druid.data.input.impl.DoubleDimensionSchema
- getDimensionHandler() - Method in class org.apache.druid.data.input.impl.FloatDimensionSchema
- getDimensionHandler() - Method in class org.apache.druid.data.input.impl.LongDimensionSchema
- getDimensionHandler() - Method in class org.apache.druid.data.input.impl.NewSpatialDimensionSchema
- getDimensionHandler() - Method in class org.apache.druid.data.input.impl.StringDimensionSchema
- getDimensionHandler() - Method in class org.apache.druid.segment.AutoTypeColumnSchema
- getDimensionHandler() - Method in class org.apache.druid.segment.NestedDataColumnSchema
- getDimensionHandlers() - Method in class org.apache.druid.frame.segment.columnar.FrameQueryableIndex
- 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 exception org.apache.druid.query.groupby.epinephelinae.UnexpectedMultiValueDimensionException
- 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.NestedCommonFormatColumnHandler
- getDimensionName() - Method in class org.apache.druid.segment.NestedDataColumnHandlerV4
- getDimensionName() - Method in class org.apache.druid.segment.StringDimensionHandler
- getDimensionNames() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- 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
- 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.ArrayContainsElementFilter
- 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.EqualityFilter
- 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.IsBooleanDimFilter
- 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.NullFilter
- getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.OrDimFilter
- getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.RangeFilter
- 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
- getDimensionRangeSet(String) - Method in class org.apache.druid.query.filter.TypedInFilter
- getDimensions() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- getDimensions() - Method in interface org.apache.druid.data.input.InputRow
-
Returns the dimensions that exist in this row.
- getDimensions() - Method in class org.apache.druid.data.input.ListBasedInputRow
- getDimensions() - Method in class org.apache.druid.data.input.MapBasedInputRow
- 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.TransformedInputRow
- getDimensions() - Method in class org.apache.druid.timeline.DataSegment
- getDimensions() - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- getDimensions() - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- getDimensions() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- getDimensionSchema() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- getDimensionSchema(ColumnCapabilities) - Method in interface org.apache.druid.segment.DimensionHandler
- getDimensionSchema(ColumnCapabilities) - Method in class org.apache.druid.segment.DoubleDimensionHandler
- getDimensionSchema(ColumnCapabilities) - Method in class org.apache.druid.segment.FloatDimensionHandler
- getDimensionSchema(ColumnCapabilities) - Method in class org.apache.druid.segment.LongDimensionHandler
- getDimensionSchema(ColumnCapabilities) - Method in class org.apache.druid.segment.NestedCommonFormatColumnHandler
- getDimensionSchema(ColumnCapabilities) - Method in class org.apache.druid.segment.NestedDataColumnHandlerV4
- getDimensionSchema(ColumnCapabilities) - Method in class org.apache.druid.segment.StringDimensionHandler
- 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
- getDimensionSpec() - Method in interface org.apache.druid.segment.DimensionHandler
-
Create a
DimensionSpec
for this handler - getDimensionSpec() - Method in class org.apache.druid.segment.DoubleDimensionHandler
- getDimensionSpec() - Method in class org.apache.druid.segment.FloatDimensionHandler
- getDimensionSpec() - Method in class org.apache.druid.segment.LongDimensionHandler
- getDimensionSpec() - Method in class org.apache.druid.segment.NestedCommonFormatColumnHandler
- getDimensionSpec() - Method in class org.apache.druid.segment.NestedDataColumnHandlerV4
- getDimensionsSpec() - Method in class org.apache.druid.data.input.impl.ParseSpec
-
Deprecated.
- getDimensionsSpec() - Method in class org.apache.druid.data.input.InputRowSchema
- getDimensionsSpec() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
- getDimensionsSpec() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
-
Returns dimensionsSpec from the ingestionSpec.
- getDimensionsSpec() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
- getDimensionsSpec() - Method in class org.apache.druid.timeline.CompactionState
- getDimensionValue(String) - Method in class org.apache.druid.query.topn.DimensionAndMetricValueExtractor
- 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
- getDimName() - Method in class org.apache.druid.data.input.impl.SpatialDimensionSchema
-
Deprecated.
- getDims() - Method in class org.apache.druid.data.input.impl.NewSpatialDimensionSchema
- getDims() - Method in class org.apache.druid.data.input.impl.SpatialDimensionSchema
-
Deprecated.
- getDims() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
- getDimSelector() - Method in class org.apache.druid.query.topn.TopNParams
- getDimType() - Method in class org.apache.druid.query.topn.DimValHolder
- 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.QueryableIndexIndexableAdapter
- getDimValueUtf8Lookup(String) - Method in class org.apache.druid.segment.MMappedIndex
- getDirection() - Method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- getDirection() - Method in class org.apache.druid.query.operator.ColumnWithDirection
- getDirectionInt() - Method in enum org.apache.druid.query.operator.ColumnWithDirection.Direction
- getDirectMemorySizeBytes() - Method in class org.apache.druid.utils.RuntimeInfo
- getDirectory() - Method in class org.apache.druid.guice.ExtensionsConfig
- getDistributionType() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- getDomainDimensions() - Method in interface org.apache.druid.timeline.partition.BucketNumberedShardSpec
- getDomainDimensions() - Method in interface org.apache.druid.timeline.partition.BuildingShardSpec
- getDomainDimensions() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- getDomainDimensions() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- getDomainDimensions() - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- getDomainDimensions() - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- getDomainDimensions() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- getDomainDimensions() - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- getDomainDimensions() - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
Get dimensions who have possible range for the rows this shard contains.
- getDomainDimensions() - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- getDouble() - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
- 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() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.CountAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
- 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.ExpressionLambdaAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- 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() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
- 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() - Method in class org.apache.druid.query.aggregation.NoopAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
- getDouble() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.SingleValueAggregator
- getDouble() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
- getDouble() - Method in interface org.apache.druid.segment.BaseDoubleColumnValueSelector
- getDouble() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
- getDouble() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- 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() - 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, ifNullHandling.replaceWithDefault()
is set to false. - getDouble() - Method in class org.apache.druid.segment.ObjectBasedColumnSelector
- getDouble() - Method in class org.apache.druid.segment.ObjectColumnSelector
- 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.BaseExpressionColumnValueSelector
- getDouble() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- getDouble() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector
- getDouble(int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- getDouble(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.FloatColumnAccessorBase
- getDouble(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.LongColumnAccessorBase
- getDouble(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- getDouble(int) - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Get the primitive
double
representation of the row. - getDouble(int) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- getDouble(int) - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix.MatrixRow
- getDouble(int) - Method in interface org.apache.druid.segment.historical.HistoricalColumnSelector
- getDouble(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.LongAnyBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SingleValueBufferAggregator
- getDouble(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
- getDoubleArray(double[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getDoubleArray(long, double[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getDoubleArrayFieldWriter(ColumnValueSelector) - Static method in class org.apache.druid.frame.field.NumericArrayFieldWriter
-
Returns the writer for ARRAY
- getDoubleBuffer() - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- getDoubleCardinality() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- getDoubleDictionary() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getDoubleDictionary() - Method in interface org.apache.druid.segment.nested.NestedCommonFormatColumn
- getDoubleDictionary() - Method in class org.apache.druid.segment.nested.ScalarDoubleColumn
- getDoubleDictionary() - Method in class org.apache.druid.segment.nested.VariantColumn
- 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
- getDoubleObjectEstimateSize() - Static method in class org.apache.druid.segment.nested.StructuredDataProcessor
- getDoublePredicateSupplier() - Method in class org.apache.druid.query.filter.BoundDimFilter
- getDoubleSerializer(String, SegmentWriteOutMedium, String, ByteOrder, CompressionStrategy, Closer) - 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.math.expr.vector.ExprEvalDoubleVector
- getDoubleVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalLongVector
- getDoubleVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalObjectVector
- getDoubleVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalVector
- 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
- getDoubleVector(String) - Method in interface org.apache.druid.math.expr.Expr.VectorInputBinding
- getDoubleVector(String) - Method in class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- getDuration() - Method in class org.apache.druid.indexer.TaskStatus
- getDuration() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getDuration() - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- 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.
- getDurationMillis() - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- getEffectiveCpuSetCpus() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuSet.CpuSetMetric
- getEffectiveCpuSetMems() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuSet.CpuSetMetric
- getEffectiveSizeBytes() - Method in class org.apache.druid.segment.EncodedKeyComponent
-
Effective size of the key component in bytes.
- getElementMatchValue() - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- getElementMatchValueType() - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- getElementType() - Method in class org.apache.druid.segment.column.BaseTypeSignature
- getElementType() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- getElementType() - Method in interface org.apache.druid.segment.column.TypeSignature
- getEmissionDuration() - Method in class org.apache.druid.java.util.metrics.DruidMonitorSchedulerConfig
- getEnabledInstance() - Static method in class org.apache.druid.js.JavaScriptConfig
- getEnableJoinFilterPushDown() - Method in class org.apache.druid.query.QueryContext
- getEnableJoinFilterRewrite() - Method in class org.apache.druid.query.QueryContext
- getEnableJoinFilterRewriteValueColumnFilters() - Method in class org.apache.druid.query.QueryContext
- getEnableJoinLeftScanDirect() - Method in class org.apache.druid.query.QueryContext
- getEnableLookupSyncOnStartup() - Method in class org.apache.druid.query.lookup.LookupConfig
- getEnableParallelMerges() - Method in class org.apache.druid.query.QueryContext
- getEnableRewriteJoinToFilter() - Method in class org.apache.druid.query.QueryContext
- getEnclosingArea(Node, Node) - Static method in class org.apache.druid.collections.spatial.RTreeUtils
- getEncodedValue(ActualType, boolean) - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- 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.NestedCommonFormatColumnHandler
- getEncodedValueSelectorComparator() - Method in class org.apache.druid.segment.NestedDataColumnHandlerV4
- getEncodedValueSelectorComparator() - Method in class org.apache.druid.segment.StringDimensionHandler
- getEncoding() - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- getEncodingString() - Method in enum org.apache.druid.java.util.http.client.HttpClientConfig.CompressionCodec
-
Get the header-ified name of this encoding, which should go in "Accept-Encoding" and "Content-Encoding" headers.
- getEnd() - Method in class org.apache.druid.frame.key.ClusterByPartition
-
Get the ending key for this range.
- getEnd() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getEnd() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- getEnd() - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- getEnd() - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- getEnd() - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- getEnd() - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- getEnd() - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- 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
- getEndRootPartitionId() - Method in class org.apache.druid.timeline.DataSegment
- getEndRootPartitionId() - Method in interface org.apache.druid.timeline.Overshadowable
-
See doc of
Overshadowable.getStartRootPartitionId()
. - getEndRootPartitionId() - Method in class org.apache.druid.timeline.partition.NumberedOverwritePartialShardSpec
- getEndRootPartitionId() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- getEndRootPartitionId() - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
Returns the end root partition ID of the atomic update group which this segment belongs to.
- getEndRow() - Method in class org.apache.druid.query.rowsandcols.util.FindResult
- getEndTuple() - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- getEndTuple() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- getEntityTag() - Method in class org.apache.druid.query.context.ResponseContext
- getEntry(String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Retrieves the entry with the given id.
- getEntrySpan(int) - Method in class org.apache.druid.segment.serde.cell.CellIndexReader
- getEntrySpan(int) - Method in class org.apache.druid.segment.serde.cell.IntIndexView
- getEntryTable(String) - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getEntryType() - Method in interface org.apache.druid.metadata.MetadataStorageActionHandlerTypes
- getEnum(String, Class<E>, E) - Method in class org.apache.druid.query.QueryContext
- getEnumeratedProbabilities() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- getEnumeratedValues() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- getEnumIfPresent(Class<T>, String) - Static method in class org.apache.druid.common.guava.GuavaUtils
-
Like Guava's Enums.getIfPresent, with some differences.
- getEnv(String) - Method in class org.apache.druid.metadata.EnvironmentVariableDynamicConfigProvider
- getEqualityIndex(String, ExprEval<?>, ColumnType, ColumnIndexSelector, DruidPredicateFactory) - Static method in class org.apache.druid.query.filter.EqualityFilter
- 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 class org.apache.druid.error.DruidException.Failure
- getErrorCode() - Method in exception org.apache.druid.error.DruidException
- getErrorCode() - Method in exception org.apache.druid.query.QueryException
- getErrorMessage() - Method in interface org.apache.druid.indexer.Jobby
- getErrorMessage() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- getErrorMessageTransformFunction() - Method in class org.apache.druid.common.exception.AllowedRegexErrorResponseTransformStrategy
- getErrorMessageTransformFunction() - Method in interface org.apache.druid.common.exception.ErrorResponseTransformStrategy
-
Return a function for checking and transforming the error message if needed.
- getErrorMessageTransformFunction() - Method in class org.apache.druid.common.exception.NoErrorResponseTransformStrategy
- getErrorMsg() - Method in exception org.apache.druid.frame.write.InvalidFieldException
- getErrorMsg() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- getErrorMsg() - Method in class org.apache.druid.indexer.TaskStatus
- getErrorMsg() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getErrorType() - Method in class org.apache.druid.segment.incremental.ParseExceptionReport
- getEscape() - Method in class org.apache.druid.query.filter.LikeDimFilter
- getEstimatedSize() - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
-
Estimated size in bytes of the data processed
- getEvent() - Method in class org.apache.druid.data.input.MapBasedRow
- getEvents() - Method in class org.apache.druid.query.scan.ScanResultValue
- getEventsToEmit() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getExactLongFromDecimalString(String) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
-
Convert a string representing a decimal value to a long.
- getException() - Method in class org.apache.druid.common.config.ConfigManager.SetResult
- getExceptionCaught() - Method in class org.apache.druid.frame.file.FrameFilePartialFetch
-
The exception that was encountered, if
FrameFilePartialFetch.isExceptionCaught()
is true. - getExcludeList() - Method in class org.apache.druid.guice.ModulesConfig
- 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
- getExecutorService() - Method in class org.apache.druid.frame.processor.FrameProcessorExecutor
-
Returns the underlying executor service used by this executor.
- getExpansionCost(Node, Point) - Static method in class org.apache.druid.collections.spatial.RTreeUtils
- getExpectedStatus() - Method in enum org.apache.druid.error.DruidException.Category
- getExpectedStatus() - Method in enum org.apache.druid.query.QueryException.FailType
- getExpectedType() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- getExponent(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- GetExponent() - Constructor for class org.apache.druid.math.expr.Function.GetExponent
- getExpr() - Method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- 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.ExpressionLambdaAggregatorFactory.FactorizePlan
- 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
-
Gets the original expression that was planned
- getExpression() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- getExtendedIndexesMerger() - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- getExtendedIndexesMerger() - Method in class org.apache.druid.segment.StringDimensionMergerV9
- getExtension() - Method in enum org.apache.druid.utils.CompressionUtils.Format
- getExtensionFilesToLoad() - Method in class org.apache.druid.guice.ExtensionsLoader
-
Find all the extension files that should be loaded by druid.
- 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.AbstractSerializableLongObjectPairSerde
- 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.SerializablePairLongStringComplexMetricSerde
- getExtractor() - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- 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.OnheapIncrementalIndex
- getFailedSendingTimeCounter() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getFailType() - Method in exception org.apache.druid.query.QueryException
- getFastestPartitionInitializedTime() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
- getfd(FileDescriptor) - Static method in class org.apache.druid.java.util.common.io.NativeIO
-
Get system file descriptor (int) from FileDescriptor object.
- getFeatureSpec() - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- getFeatureSpec() - Method in class org.apache.druid.data.input.impl.JSONParseSpec
- getFeed() - Method in interface org.apache.druid.java.util.emitter.core.Event
- getFeed() - Method in class org.apache.druid.java.util.emitter.service.AlertEvent
- getFeed() - Method in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- getFeed() - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- getField() - Method in class org.apache.druid.query.filter.IsBooleanDimFilter
- getField() - Method in class org.apache.druid.query.filter.NotDimFilter
- getField() - Method in class org.apache.druid.segment.nested.NestedPathField
- getField(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getField(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.NestedDataColumnV3
- getField(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.NestedDataColumnV4
- getField(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.NestedDataColumnV5
- getField(T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.ByteFieldWriter
- getField(T) - Method in interface org.apache.druid.segment.serde.MetaSerdeHelper.IntFieldWriter
- getFieldFileName(String, String, int) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getFieldFileName(String, String, int) - Method in class org.apache.druid.segment.nested.NestedDataColumnV3
- getFieldFileName(String, String, int) - Method in class org.apache.druid.segment.nested.NestedDataColumnV4
- getFieldFileName(String, String, int) - Method in class org.apache.druid.segment.nested.NestedDataColumnV5
- getFieldName() - Method in enum org.apache.druid.data.input.impl.systemfield.SystemField
-
Name of this system field.
- 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.firstlast.first.DoubleFirstAggregatorFactory
- getFieldName() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getFieldName() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getFieldName() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getFieldName() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getFieldName() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getFieldName() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getFieldName() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- 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.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
- getFieldName() - Method in class org.apache.druid.query.aggregation.SingleValueAggregatorFactory
- getFieldNames() - Method in class org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser
- getFieldNames() - Method in class org.apache.druid.java.util.common.parsers.JavaScriptParser
- getFieldNames() - Method in class org.apache.druid.java.util.common.parsers.JSONPathParser
- getFieldNames() - Method in class org.apache.druid.java.util.common.parsers.JSONToLowerParser
-
Deprecated.
- getFieldNames() - Method in interface org.apache.druid.java.util.common.parsers.Parser
-
Deprecated.
- getFieldNames() - Method in class org.apache.druid.java.util.common.parsers.RegexParser
- 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.data.input.impl.systemfield.SystemFields
- getFields() - Method in class org.apache.druid.java.util.common.parsers.JSONPathSpec
- getFields() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
- getFields() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- 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
- getFieldTypeInfo() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getFieldTypeInfo() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getFieldTypeInfo() - Method in interface org.apache.druid.segment.nested.NestedCommonFormatColumn
- getFieldTypeInfo() - Method in class org.apache.druid.segment.nested.VariantColumn
- getFieldTypeInfo() - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- getFile() - Method in class org.apache.druid.data.input.impl.FileEntity
- 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
- getFileNameBase() - Method in class org.apache.druid.segment.nested.NestedDataColumnMetadata
- getFileNum() - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- getFilePathForManifest(String) - Method in interface org.apache.druid.storage.ExportStorageProvider
- getFilePathForManifest(String) - Method in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- getFiles() - Method in class org.apache.druid.data.input.impl.LocalInputSource
- getFiles() - Method in class org.apache.druid.java.util.common.FileUtils.FileCopyResult
- getFileSize(File) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Computes the size of the file.
- getFilter() - Method in class org.apache.druid.data.input.impl.LocalInputSource
- 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.filter.FilterBundle.IndexBundleInfo
- getFilter() - Method in class org.apache.druid.query.filter.FilterBundle.MatcherBundleInfo
- getFilter() - Method in class org.apache.druid.query.FilteredDataSource
- getFilter() - Method in class org.apache.druid.query.groupby.GroupByQuery
- getFilter() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- getFilter() - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- getFilter() - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- 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
-
Returns the child filters for this filter.
- 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.ArrayContainsElementFilter
- getFilterTuning() - Method in class org.apache.druid.query.filter.BoundDimFilter
- getFilterTuning() - Method in class org.apache.druid.query.filter.EqualityFilter
- 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.NullFilter
- getFilterTuning() - Method in class org.apache.druid.query.filter.RangeFilter
- 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
- getFilterTuning() - Method in class org.apache.druid.query.filter.TypedInFilter
- getFinalizedType() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Deprecated.
- getFinalizeExpressionString() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getFirstEventTimestamp(ScanQuery.ResultFormat) - Method in class org.apache.druid.query.scan.ScanResultValue
- getFlattenSpec() - Method in class org.apache.druid.data.input.impl.NestedDataParseSpec
- getFlattenSpec() - Method in class org.apache.druid.data.input.impl.NestedInputFormat
- getFlippedBit(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Gets the position of the flipped bit within a sequence word.
- getFloat() - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
- getFloat() - Method in interface org.apache.druid.query.aggregation.Aggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.constant.LongConstantAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.CountAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
- 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.ExpressionLambdaAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- 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() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
- 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() - Method in class org.apache.druid.query.aggregation.NoopAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
- getFloat() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.SingleValueAggregator
- getFloat() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
- getFloat() - Method in interface org.apache.druid.segment.BaseFloatColumnValueSelector
- getFloat() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
- getFloat() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- 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, ifNullHandling.replaceWithDefault()
is set to false. - getFloat() - Method in class org.apache.druid.segment.ObjectBasedColumnSelector
- getFloat() - Method in class org.apache.druid.segment.ObjectColumnSelector
- 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.BaseExpressionColumnValueSelector
- getFloat() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- getFloat() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector
- getFloat(int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- getFloat(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.DoubleColumnAccessorBase
- getFloat(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.LongColumnAccessorBase
- getFloat(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- getFloat(int) - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Get the primitive
float
representation of the row. - getFloat(int) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- getFloat(int) - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix.MatrixRow
- getFloat(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getFloat(String) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
Float
, returning {@link null} if the context value is not set. - getFloat(String, float) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
float
, returning the default value if the context value is not set. - getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.LongAnyBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SingleValueBufferAggregator
- getFloat(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
- getFloatArray(float[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getFloatArray(long, float[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getFloatArrayFieldWriter(ColumnValueSelector) - Static method in class org.apache.druid.frame.field.NumericArrayFieldWriter
-
Returns the writer for ARRAY
- 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, Closer) - 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
- getFlushCount() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getFlushMillis() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getFlushTimeOut() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- 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
- getFoldExpressionString() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getForceGuaranteedRollupIncompatiblityReason() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- getForceGuaranteedRollupIncompatiblityReason() - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- getForceGuaranteedRollupIncompatiblityReason() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- getForceGuaranteedRollupIncompatiblityReason() - Method in interface org.apache.druid.indexer.partitions.PartitionsSpec
- getForceGuaranteedRollupIncompatiblityReason() - Method in class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
- getFormat() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
- getFormat() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
- getFormat() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getFormat() - Method in interface org.apache.druid.segment.DimensionIndexer
- getFormat() - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- getFormat(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
- getFormat(String) - Method in interface org.apache.druid.segment.IndexableAdapter
- getFormat(String) - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
- getFormatString() - Method in class org.apache.druid.query.DruidProcessingConfig
- getFormatter(Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- getFormatter(Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- getFormatter(Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- getFormatter(Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- getFormatter(Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- getFormatVersion() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- getFormatVersion() - Method in class org.apache.druid.segment.NestedDataColumnSchema
- getForwardedId(int) - Method in class org.apache.druid.segment.IdMapping
-
Get the substitute index, given the original
- getFrame() - Method in class org.apache.druid.query.FrameSignaturePair
- getFrame() - Method in class org.apache.druid.query.operator.window.WindowFramedAggregateProcessor
- getFrameEndPosition(int) - Method in class org.apache.druid.frame.file.FrameFileFooter
-
Get the last byte for the frame specified.
- getFrameMemoryAllocator() - Method in class org.apache.druid.frame.processor.OutputChannel
-
Returns the memory allocator for the writable channel.
- getFrameMemoryAllocator() - Method in class org.apache.druid.frame.processor.PartitionedOutputChannel
-
Returns the memory allocator for the writable channel.
- getFrames() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- getFreeHeapSizeBytes() - Method in class org.apache.druid.utils.RuntimeInfo
- getFreeVariables() - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Total set of 'free' inputs of an
Expr
, that are not supplied by aLambdaExpr
binding - getFromExtensions(Class<T>) - Method in class org.apache.druid.guice.ExtensionsLoader
-
Look for implementations for the given class from both classpath and extensions directory, using
ServiceLoader
. - getFromIndex(long) - Method in class org.apache.druid.query.operator.OffsetLimit
-
Returns the first row index to fetch.
- getFullResult() - Method in class org.apache.druid.query.context.ResponseContext.SerializationResult
- getFunction() - Method in class org.apache.druid.data.input.impl.JavaScriptParseSpec
- 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
- getFunction(String) - Static method in class org.apache.druid.math.expr.Parser
-
Get
Function
byNamedFunction.name()
- getGlobalIdToLocalId() - Method in class org.apache.druid.segment.nested.LocalDimensionDictionary
- getGlobalLookup() - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- getGlobalLookup() - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- getGlobalLookup() - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- getGlobalLookup() - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- getGrammarFileName() - Method in class org.apache.druid.math.expr.antlr.ExprLexer
- getGrammarFileName() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- 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.
- getGranularity(String, ObjectMapper) - Method in class org.apache.druid.query.QueryContext
- getGranularitySpec() - Method in class org.apache.druid.timeline.CompactionState
- getGroupId() - Method in class org.apache.druid.indexer.TaskIdentifier
- getGroupId() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getGroupingCols() - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- getGroupingEngine() - Method in class org.apache.druid.query.groupby.GroupByQueryRunnerFactory
- getGroupingKeySize() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.DictionaryBuildingSingleValueStringGroupByVectorColumnSelector
- 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.NilGroupByVectorColumnSelector
- 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
- getGroupingKeySizeBytes() - Method in class org.apache.druid.query.groupby.epinephelinae.column.FixedWidthGroupByColumnSelectorStrategy
- getGroupingKeySizeBytes() - 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.
- getGroupingKeySizeBytes() - Method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy
- getGroupings() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- getGrowthCount() - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- getGrowthCount() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- getGzBaseName(String) - Static method in class org.apache.druid.utils.CompressionUtils
-
Get the file name without the .gz extension
- 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
- getHeaders() - Method in class org.apache.druid.java.util.http.client.Request
- getHeapIndexForOffset(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper.BufferGrouperOffsetHeapIndexUpdater
- getHeapSize() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
- getHiveFormat() - Method in enum org.apache.druid.java.util.common.granularity.GranularityType
- getHost() - Method in class org.apache.druid.indexer.TaskLocation
- getHost() - Method in class org.apache.druid.java.util.emitter.service.AlertEvent
- getHost() - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- getHost() - Method in class org.apache.druid.java.util.http.client.HttpClientProxyConfig
- getHost() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- getHost() - Method in exception org.apache.druid.query.QueryException
- getHttpAuthenticationPasswordProvider() - Method in class org.apache.druid.data.input.impl.HttpInputSource
- getHttpAuthenticationUsername() - Method in class org.apache.druid.data.input.impl.HttpInputSource
- getHttpTimeoutAllowanceFactor() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getHumanReadableBytes(String, long) - Method in class org.apache.druid.query.QueryContext
- getHumanReadableBytes(String, HumanReadableBytes) - Method in class org.apache.druid.query.QueryContext
- getId() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
- getId() - Method in class org.apache.druid.frame.segment.FrameSegment
- getId() - Method in class org.apache.druid.indexer.TaskIdentifier
- getId() - Method in class org.apache.druid.indexer.TaskInfo
- getId() - Method in class org.apache.druid.indexer.TaskStatus
- getId() - Method in class org.apache.druid.indexer.TaskStatusPlus
- 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 class org.apache.druid.segment.ArrayListSegment
- getId() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- getId() - Method in interface org.apache.druid.segment.column.StringEncodingStrategy
- getId() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.Utf8
- 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.ReadableVectorInspector
-
Returns an integer that uniquely identifies the current vector.
- getId() - Method in class org.apache.druid.segment.WrappedSegmentReference
- getId() - Method in class org.apache.druid.timeline.DataSegment
- getId(T) - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
- getId(T) - Method in class org.apache.druid.segment.DimensionDictionary
- getIdentifierExprIfIdentifierExpr() - Method in interface org.apache.druid.math.expr.Expr
-
Returns an
IdentifierExpr
if it is one, else null - getIdentifierIfIdentifier() - Method in interface org.apache.druid.math.expr.Expr
-
Returns the string identifier of an
IdentifierExpr
, else null. - getIdentity() - Method in class org.apache.druid.audit.AuditInfo
- getIdForNull() - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
- getIdForNull() - Method in class org.apache.druid.segment.DimensionDictionary
- getImmutableBitmap() - Method in class org.apache.druid.collections.spatial.ImmutableFloatNode
- getImmutableBitmap() - Method in interface 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() - Method in class org.apache.druid.query.filter.FilterBundle.BundleInfo
- getIndex() - Method in class org.apache.druid.query.filter.FilterBundle
- getIndex() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
- getIndex() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.MetricDesc
- getIndex() - Method in class org.apache.druid.segment.nested.NestedPathArrayElement
- getIndexCapabilities() - Method in interface org.apache.druid.query.filter.FilterBundle.IndexBundle
- getIndexCapabilities() - Method in class org.apache.druid.query.filter.FilterBundle.SimpleIndexBundle
- getIndexCapabilities() - Method in class org.apache.druid.segment.index.AllFalseBitmapColumnIndex
- getIndexCapabilities() - Method in class org.apache.druid.segment.index.AllTrueBitmapColumnIndex
- getIndexCapabilities() - Method in class org.apache.druid.segment.index.AllUnknownBitmapColumnIndex
- getIndexCapabilities() - Method in interface org.apache.druid.segment.index.BitmapColumnIndex
- getIndexCapabilities() - Method in class org.apache.druid.segment.index.SimpleBitmapColumnIndex
- getIndexer() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.DimensionDesc
- getIndexes() - Method in class org.apache.druid.query.filter.FilterBundle.IndexBundleInfo
- getIndexInfo() - Method in interface org.apache.druid.query.filter.FilterBundle.IndexBundle
- getIndexInfo() - Method in class org.apache.druid.query.filter.FilterBundle.SimpleIndexBundle
- getIndexSpec() - Method in class org.apache.druid.timeline.CompactionState
- getIndexSupplier() - Method in class org.apache.druid.frame.read.columnar.ColumnPlus
- getIndexSupplier() - Method in interface org.apache.druid.segment.column.ColumnHolder
- getIndexSupplier(String) - Method in interface org.apache.druid.query.filter.ColumnIndexSelector
-
Get the
ColumnIndexSupplier
of a column. - getIndexSupplier(String) - Method in class org.apache.druid.segment.ColumnSelectorColumnIndexSelector
- getIndexSupplier(String, ColumnIndexSelector) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- getIndexSupplier(String, ColumnIndexSelector) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- getIndexSupplier(String, ColumnIndexSelector) - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- getIndexSupplier(String, ColumnIndexSelector) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- getIndexSupplier(String, ColumnIndexSelector) - Method in interface org.apache.druid.segment.VirtualColumn
-
Get the
ColumnIndexSupplier
for the specified virtual column, with the assistance of aColumnIndexSelector
to allow reading things from segments. - getIndexSupplier(String, ColumnIndexSelector) - Method in class org.apache.druid.segment.VirtualColumns
-
Get the
ColumnIndexSupplier
of the specified virtual column, with the assistance of aColumnSelector
to allow reading things from segments. - getIndividualFieldSize() - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
-
Returns the field size that each element in the reader array consumes.
- getIndividualValueAtMemory(long) - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
-
Returns the value of the individual element written at the given position
- getInfo() - Method in class org.apache.druid.query.filter.FilterBundle
- getIngestionState() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- getInitialCombineValueExpressionString() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getInitialOffset() - Method in class org.apache.druid.collections.spatial.ImmutableFloatNode
- getInitialOffset() - Method in interface org.apache.druid.collections.spatial.ImmutableNode
- getInitialSizeBytes() - Method in class org.apache.druid.query.aggregation.AggregatorAndSize
-
Initial size of the aggregator in bytes including JVM object overheads.
- getInitialValue() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory.FactorizePlan
- getInitialValueExpressionString() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getInitPosition() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getInput() - Method in exception org.apache.druid.java.util.common.parsers.ParseException
- getInput() - Method in class org.apache.druid.segment.incremental.ParseExceptionReport
- getInputColumn() - Method in class org.apache.druid.query.operator.window.value.WindowValueProcessorBase
- getInputRows() - Method in class org.apache.druid.data.input.InputRowListPlusRawValues
- getInputRows() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
-
Total number of input 'rows' processed by the
ParallelMergeCombiningSequence
- getInputRowSchema() - Method in class org.apache.druid.data.input.TextReader
- getInputRowTuple(List<String>, InputRow) - Static method in class org.apache.druid.timeline.partition.BaseDimensionRangeShardSpec
- getInputs() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory.FactorizePlan
- getInputSequences() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
-
Total number of input
Sequence
processed byParallelMergeCombiningSequence
- getInputStream(URI) - Method in interface org.apache.druid.segment.loading.URIDataPuller
-
Create a new InputStream based on the URI
- getInstance() - Static method in class org.apache.druid.java.util.http.client.response.StatusResponseHandler
- getInstance() - Static method in class org.apache.druid.math.expr.ExpressionTypeFactory
- getInstance() - Static method in class org.apache.druid.metadata.TaskLookup.ActiveTaskLookup
- getInstance() - Static method in class org.apache.druid.query.extraction.IdentityExtractionFn
- getInstance() - Static method in class org.apache.druid.segment.column.ColumnTypeFactory
- getInstance() - Static method in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
- getInstance() - Static method in class org.apache.druid.segment.serde.NoIndexesColumnIndexSupplier
- getInstance() - Static method in class org.apache.druid.storage.NilStorageConnector
- getInSubQueryThreshold() - Method in class org.apache.druid.query.QueryContext
- getInSubQueryThreshold(int) - Method in class org.apache.druid.query.QueryContext
- getInt() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getInt(int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- getInt(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.DoubleColumnAccessorBase
- getInt(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.FloatColumnAccessorBase
- getInt(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.LongColumnAccessorBase
- getInt(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- getInt(int) - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Get the primitive
int
representation of the row. - getInt(int) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- getInt(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getInt(String) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
Integer
, returning {@link null} if the context value is not set. - getInt(String, int) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
int
, returning the default value if the context value is not set. - getInt(Map<String, Object>, String, Integer) - Static method in class org.apache.druid.java.util.common.MapUtils
- getIntArray(int[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getIntArray(long, int[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getIntermediateCombineDegree() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Get the "intermediate"
ColumnType
for this aggregator. - getIntermediateType() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
-
actual type is
HyperLogLogCollector
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
-
actual type is
SerializablePairLongString
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
-
actual type is
SerializablePairLongString
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
-
actual type is
Histogram
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
-
actual type is
HyperLogLogCollector
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
-
actual type is
DoubleMeanHolder
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.SimpleDoubleAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.SimpleFloatAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.SimpleLongAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.SingleValueAggregatorFactory
- getIntermediateType() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- getInternalFileName(String, String) - Static method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
-
Nested field columns are stored in separate
- getInternalFileName(String, String) - Static method in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- getInternalFilenames() - Method in class org.apache.druid.java.util.common.io.smoosh.SmooshedFileMapper
- getInterval() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- 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.SegmentDescriptor
- getInterval() - Method in class org.apache.druid.query.topn.BySegmentTopNResultValue
- getInterval() - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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
- getInterval() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getInterval() - Method in class org.apache.druid.timeline.DataSegment
- getInterval() - Method in interface org.apache.druid.timeline.LogicalSegment
- getInterval() - Method in class org.apache.druid.timeline.SegmentId
- getInterval() - Method in class org.apache.druid.timeline.TimelineObjectHolder
- getInterval() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline.PartitionChunkEntry
- getIntervalEnd() - Method in class org.apache.druid.timeline.SegmentId
- 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
- getIntervalStart() - Method in class org.apache.druid.timeline.SegmentId
- getIntrospectHandler() - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
- getIp() - Method in class org.apache.druid.audit.AuditInfo
- getIsInputHyperUnique() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
- getIsNullUnlessAggregated() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getIterable() - Method in class org.apache.druid.java.util.common.guava.SimpleSequence
-
Retrieve the original Iterable.
- getIterable(Interval) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- getIterable(Interval) - Method in class org.apache.druid.java.util.common.granularity.Granularity
-
Return an iterable of granular buckets that overlap a particular interval.
- getIterator() - Method in class org.apache.druid.segment.data.FixedIndexedIntWriter
- getIterator() - Method in class org.apache.druid.segment.data.FixedIndexedWriter
- getJacksonModules() - Method in class org.apache.druid.guice.NestedDataModule
- getJacksonModules() - Method in interface org.apache.druid.initialization.DruidModule
- getJacksonModules() - Method in class org.apache.druid.initialization.TombstoneDataStorageModule
- getJacksonModules() - Method in class org.apache.druid.storage.StorageConnectorModule
- getJacksonModulesList() - Static method in class org.apache.druid.guice.NestedDataModule
- 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
- getJoinableFactory() - Method in class org.apache.druid.segment.join.JoinableFactoryWrapper
- getJoinableFactoryWrapper() - Method in class org.apache.druid.query.JoinDataSource
- getJoinBaseTableFilter() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
If the original data source is a join data source and there is a DimFilter on the base table data source, that DimFilter is returned here
- getJoinColumn() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
- getJoinFields() - Method in class org.apache.druid.query.operator.join.JoinPartDefn
- getJoinFilterRewriteMaxSize() - Method in class org.apache.druid.query.QueryContext
- 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.
- getJsonCompression() - Method in class org.apache.druid.segment.IndexSpec
- getJsonMapper(Injector) - Method in class org.apache.druid.guice.DruidSecondaryModule
- getJsonMapperOnlyNonNullValueSerialization(Injector) - Method in class org.apache.druid.guice.DruidSecondaryModule
- getJsonProvider() - Method in class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- getJsonProvider() - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
- getK8sPodName() - Method in class org.apache.druid.indexer.TaskLocation
- getKeepNullColumns() - Method in class org.apache.druid.data.input.impl.JSONParseSpec
- getKey() - Method in class org.apache.druid.audit.AuditEntry
- getKey() - Method in class org.apache.druid.guice.KeyHolder
- getKey() - Method in class org.apache.druid.metadata.MetadataCASUpdate
- getKey() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.Entry
- getKey() - Method in class org.apache.druid.query.groupby.epinephelinae.ReusableEntry
-
Returns the key, which enables modifying the key.
- 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
- getKeyColumn() - Method in class org.apache.druid.metadata.MetadataCASUpdate
- getKeyColumns() - Method in class org.apache.druid.segment.loading.BroadcastJoinableMMappedQueryableSegmentizerFactory
- getKeys() - Method in interface org.apache.druid.indexer.TaskMetricsGetter
- getLane() - Method in class org.apache.druid.query.QueryContext
- getLargeEventsToEmit() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getLast() - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- getLastCompactionState() - Method in class org.apache.druid.timeline.DataSegment
- getLastRowIndex() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- getLastRowIndex() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
- getLatest(int) - Method in class org.apache.druid.utils.CircularBuffer
-
Access object at a given index, starting from the latest entry added and moving backwards.
- getLatestNumBytesForDenseStorage() - Static method in class org.apache.druid.hll.HyperLogLogCollector
- getLatestVersion(DataDescriptor, Pattern) - Method in interface org.apache.druid.data.SearchableVersionedDataFinder
-
Get's a DataDescriptor to the latest "version" of a data quantum starting with descriptorBase and matching based on pattern
- getLeafOperators() - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- getLeft() - Method in class org.apache.druid.query.JoinDataSource
- getLeftExpr() - Method in class org.apache.druid.segment.join.Equality
- getLeftFilter() - Method in class org.apache.druid.query.JoinDataSource
- getLength() - Method in class org.apache.druid.frame.read.columnar.ColumnPlus
- getLength() - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldLambdaBinding
- getLength() - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianMapLambdaBinding
- getLength() - Method in class org.apache.druid.math.expr.ApplyFunction.FoldLambdaBinding
- getLength() - Method in interface org.apache.druid.math.expr.ApplyFunction.IndexableFoldLambdaBinding
-
Total number of bindings in this binding
- getLength() - Method in interface org.apache.druid.math.expr.ApplyFunction.IndexableMapLambdaObjectBinding
-
Total number of bindings in this binding
- getLength() - Method in class org.apache.druid.math.expr.ApplyFunction.MapLambdaBinding
- getLength() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexColumn
- getLength() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn
- getLength() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn
- getLength() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn
- 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
- getLength() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getLengthOfEncodedKeyComponent(int[]) - Method in class org.apache.druid.segment.StringDimensionHandler
- 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(StructuredData) - Method in class org.apache.druid.segment.NestedCommonFormatColumnHandler
- getLengthOfEncodedKeyComponent(StructuredData) - Method in class org.apache.druid.segment.NestedDataColumnHandlerV4
- getLevelToMergedBatches() - Method in class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- getLevelToTotalBatches() - Method in class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- getLexicographicMergedDimensions(List<IndexableAdapter>) - Static method in interface org.apache.druid.segment.IndexMerger
- getLhs() - Method in class org.apache.druid.collections.SerializablePair
- getLhsExprs(String) - Method in class org.apache.druid.segment.join.filter.Equiconditions
- getLifecycle(Injector) - Method in class org.apache.druid.guice.LifecycleModule
- 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.operator.OffsetLimit
- getLimit() - Method in class org.apache.druid.query.search.SearchQuery
- getLimit() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
- getLimitOrMax() - Method in class org.apache.druid.query.operator.OffsetLimit
- getLimitSpec() - Method in class org.apache.druid.query.groupby.GroupByQuery
- getListDelimiter() - Method in class org.apache.druid.data.input.impl.CSVParseSpec
- getListDelimiter() - Method in class org.apache.druid.data.input.impl.DelimitedParseSpec
- getListDelimiter() - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- getListDelimiter() - Method in class org.apache.druid.data.input.impl.RegexInputFormat
- getListDelimiter() - Method in class org.apache.druid.data.input.impl.RegexParseSpec
- getListDelimiter() - Method in class org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser
- getLiteral(int, boolean) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Gets the literal word that represents the first 31 bits of the given the word (i.e.
- getLiteralBitCount(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Gets the number of set bits within the literal word
- getLiteralBits(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Gets the bits contained within the literal word
- getLiteralFields() - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
-
Set of paths which contain simple values
- getLiteralFromOneSeqFlipBit(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- getLiteralFromZeroSeqFlipBit(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- getLiteralValue() - Method in interface org.apache.druid.math.expr.Expr
-
Returns the value of expr if expr is a literal, or throws an exception otherwise.
- getLoadedImplementations(Class<T>) - Method in class org.apache.druid.guice.ExtensionsLoader
-
Returns a collection of implementations loaded.
- getLoadedModules() - Method in class org.apache.druid.guice.ExtensionsLoader
- getLoadersMap() - Method in class org.apache.druid.guice.ExtensionsLoader
- getLoadList() - Method in class org.apache.druid.guice.ExtensionsConfig
- getLoadSpec() - Method in class org.apache.druid.timeline.DataSegment
- getLocale() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
- getLocation() - Method in class org.apache.druid.data.input.impl.CloudObjectSplitWidget.LocationWithSize
- getLocation() - Method in class org.apache.druid.indexer.TaskLocation
- getLocation() - Method in class org.apache.druid.indexer.TaskStatus
- getLocation() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getLockId(String, LockType) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Returns the lock id for the given entry and the lock.
- getLocks(String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Returns the locks for the given entry
- getLockTable(String) - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getLockType() - Method in interface org.apache.druid.metadata.MetadataStorageActionHandlerTypes
- getLoggerClass() - Method in class org.apache.druid.java.util.emitter.core.LoggingEmitterConfig
- getLogicalType() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getLogicalType() - Method in class org.apache.druid.segment.column.CapabilitiesBasedFormat
- getLogicalType() - Method in interface org.apache.druid.segment.column.ColumnFormat
- getLogicalType() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- getLogicalType() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getLogicalType() - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumn.Format
- getLogicalType() - Method in interface org.apache.druid.segment.nested.NestedCommonFormatColumn
- getLogicalType() - Method in class org.apache.druid.segment.nested.NestedDataColumnSupplier
- getLogicalType() - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde.NestedColumnFormatV4
- getLogicalType() - Method in class org.apache.druid.segment.nested.ScalarDoubleColumn
- getLogicalType() - Method in class org.apache.druid.segment.nested.ScalarLongColumn
- getLogicalType() - Method in class org.apache.druid.segment.nested.VariantColumn
- getLogicalType() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- getLogLevel() - Method in class org.apache.druid.java.util.emitter.core.LoggingEmitterConfig
- getLogs(String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Returns the logs for the entry with the given id.
- getLogTable(String) - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getLogType() - Method in interface org.apache.druid.metadata.MetadataStorageActionHandlerTypes
- getLong() - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
- getLong() - Method in interface org.apache.druid.query.aggregation.Aggregator
- getLong() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.constant.LongConstantAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.CountAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
- 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.ExpressionLambdaAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- 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() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregator
- 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() - Method in class org.apache.druid.query.aggregation.NoopAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
- getLong() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.SingleValueAggregator
- getLong() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
- getLong() - Method in interface org.apache.druid.segment.BaseLongColumnValueSelector
- getLong() - Method in class org.apache.druid.segment.ConstantExprEvalSelector
- getLong() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- 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, ifNullHandling.replaceWithDefault()
is set to false. - getLong() - Method in class org.apache.druid.segment.ObjectBasedColumnSelector
- getLong() - Method in class org.apache.druid.segment.ObjectColumnSelector
- 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.BaseExpressionColumnValueSelector
- getLong() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- getLong() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector
- getLong(int) - Method in class org.apache.druid.query.groupby.ResultRow
- getLong(int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- getLong(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.DoubleColumnAccessorBase
- getLong(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.FloatColumnAccessorBase
- getLong(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- getLong(int) - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Get the primitive
long
representation of the row. - getLong(int) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- getLong(int) - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix.MatrixRow
- getLong(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getLong(String) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
Long
, returning {@link null} if the context value is not set. - getLong(String, long) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
long
, returning the default value if the context value is not set. - getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.FloatAnyBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.any.LongAnyBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.CountBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.HistogramBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.JavaScriptBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NoopBufferAggregator
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SingleValueBufferAggregator
- getLong(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
- getLong(Map<String, Object>, String, Long) - Static method in class org.apache.druid.java.util.common.MapUtils
- getLongArray(long[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getLongArray(long, long[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getLongArrayFieldWriter(ColumnValueSelector) - Static method in class org.apache.druid.frame.field.NumericArrayFieldWriter
-
Returns the writer for ARRAY
- getLongBuffer() - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- getLongCardinality() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- getLongDictionary() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getLongDictionary() - Method in interface org.apache.druid.segment.nested.NestedCommonFormatColumn
- getLongDictionary() - Method in class org.apache.druid.segment.nested.ScalarLongColumn
- getLongDictionary() - Method in class org.apache.druid.segment.nested.VariantColumn
- getLongEncoding() - Method in class org.apache.druid.segment.IndexSpec
- getLongestSharedDimOrder(List<IndexableAdapter>, DimensionsSpec) - Static method in interface org.apache.druid.segment.IndexMerger
- getLongMetric(String) - Method in class org.apache.druid.query.MetricValueExtractor
- getLongObjectEstimateSize() - Static method in class org.apache.druid.segment.nested.StructuredDataProcessor
- getLongPredicateSupplier() - Method in class org.apache.druid.query.filter.BoundDimFilter
- getLongSerializer(String, SegmentWriteOutMedium, String, ByteOrder, CompressionFactory.LongEncodingStrategy, CompressionStrategy, Closer) - 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.math.expr.vector.ExprEvalDoubleVector
- getLongVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalLongVector
- getLongVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalObjectVector
- getLongVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalVector
- 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
- getLongVector(String) - Method in interface org.apache.druid.math.expr.Expr.VectorInputBinding
- getLongVector(String) - Method in class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- getLookup() - Method in class org.apache.druid.query.dimension.LookupDimensionSpec
- getLookup() - Method in class org.apache.druid.query.lookup.LookupExtractionFn
- getLookup(List<? extends ShardSpec>) - Method in class org.apache.druid.timeline.partition.BaseDimensionRangeShardSpec
- getLookup(List<? extends ShardSpec>) - Method in interface org.apache.druid.timeline.partition.BuildingShardSpec
-
BucketNumberedShardSpec
should be used for shard spec lookup. - getLookup(List<? extends ShardSpec>) - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- getLookup(List<? extends ShardSpec>) - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- getLookup(List<? extends ShardSpec>) - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- getLookup(List<? extends ShardSpec>) - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- getLookup(List<? extends ShardSpec>) - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- getLookup(List<? extends ShardSpec>) - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- getLookup(List<? extends ShardSpec>) - Method in interface org.apache.druid.timeline.partition.ShardSpec
- getLookup(List<? extends ShardSpec>) - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- getLookupExtractorFactory() - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
- getLookupName() - Method in class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
- 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
- getLower() - Method in class org.apache.druid.query.filter.RangeFilter
- getLowerDefaultFormat() - Method in enum org.apache.druid.java.util.common.granularity.GranularityType
- getLowerOffset() - Method in class org.apache.druid.query.operator.window.WindowFrame
- getLowerOffsetClamped(int) - Method in class org.apache.druid.query.operator.window.WindowFrame
-
Calculates the applicable lower offset if the max number of rows is known.
- getMacros() - Method in class org.apache.druid.math.expr.ExprMacroTable
- getMap() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
- getMapValue(Object, String) - Method in class org.apache.druid.data.input.impl.FastJacksonJsonNodeJsonProvider
- 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. - getMask() - Method in enum org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.Feature
- getMatchableColumnValues(String, boolean, int) - Method in interface org.apache.druid.segment.join.Joinable
-
Returns all matchable values from a particular column along with a flag to tell if they are all unique in the column.
- getMatchableColumnValues(String, boolean, int) - Method in class org.apache.druid.segment.join.lookup.LookupJoinable
- getMatchableColumnValues(String, boolean, int) - Method in class org.apache.druid.segment.join.table.IndexedTableJoinable
- getMatcher() - Method in class org.apache.druid.query.filter.FilterBundle.BundleInfo
- getMatcherBundle() - Method in class org.apache.druid.query.filter.FilterBundle
- getMatcherInfo() - Method in interface org.apache.druid.query.filter.FilterBundle.MatcherBundle
- getMatcherInfo() - Method in class org.apache.druid.query.filter.FilterBundle.SimpleMatcherBundle
- getMatchers() - Method in class org.apache.druid.query.filter.FilterBundle.MatcherBundleInfo
- getMatchValue() - Method in class org.apache.druid.query.filter.EqualityFilter
- getMatchValueType() - Method in class org.apache.druid.query.filter.EqualityFilter
- getMatchValueType() - Method in class org.apache.druid.query.filter.RangeFilter
- getMatchValueType() - Method in class org.apache.druid.query.filter.TypedInFilter
- getMaxBatchSize() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- 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.ImmutableFloatNode
- getMaxCoordinates() - Method in interface 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
- getMaxCount() - Method in class org.apache.druid.frame.processor.Bouncer
- getMaxDictionarySize() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerdeFactory
-
Return max dictionary size threshold.
- getMaxFrameSize() - Method in exception org.apache.druid.frame.processor.FrameRowTooLargeException
- getMaxHeapSizeBytes() - Method in class org.apache.druid.utils.RuntimeInfo
- getMaxIngestedEventTime() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getMaxIngestedEventTime() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataResultValue
- getMaxIngestedEventTime() - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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
- getMaxIngestedEventTime() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getMaxInputSegmentBytesPerTask() - Method in class org.apache.druid.data.input.SegmentsSplitHintSpec
- 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.ExpressionLambdaAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- getMaxIntermediateSize() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
- 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
- getMaxMinorVersion() - Method in class org.apache.druid.timeline.partition.PartitionHolder
-
Returns the maximum minor version across all the added segments.
- getMaxNumFiles() - Method in class org.apache.druid.data.input.MaxSizeSplitHintSpec
- getMaxNumSegments() - Method in class org.apache.druid.data.input.SegmentsSplitHintSpec
- getMaxOnDiskStorage() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- getMaxOverflowRegister() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getMaxOverflowRegister() - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getMaxOverflowRegister() - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- getMaxOverflowValue() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getMaxOverflowValue() - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getMaxOverflowValue() - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- getMaxPerKey() - Method in class org.apache.druid.java.util.http.client.pool.ResourcePoolConfig
- getMaxQueuedBytes(long) - Method in class org.apache.druid.query.QueryContext
- getMaxRetries() - Method in class org.apache.druid.data.input.RetryingInputEntity
- getMaxRetry() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- getMaxRowsPerSegment() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- getMaxRowsPerSegment() - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- getMaxRowsPerSegment() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- getMaxRowsPerSegment() - Method in interface org.apache.druid.indexer.partitions.PartitionsSpec
-
Returns the max number of rows per segment.
- getMaxRowsPerSegmentForJson() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- getMaxRowsQueuedForOrdering() - Method in class org.apache.druid.query.scan.ScanQuery
- getMaxRowsQueuedForOrdering() - Method in class org.apache.druid.query.scan.ScanQueryConfig
- getMaxScatterGatherBytes() - Method in class org.apache.druid.query.QueryContext
- 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
- getMaxSizeBytes() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getMaxSplitSize() - Method in class org.apache.druid.data.input.MaxSizeSplitHintSpec
- getMaxStringBytes() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
- getMaxStringBytes() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getMaxStringBytes() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- getMaxSubqueryMemoryBytes(String) - Method in class org.apache.druid.query.QueryContext
- getMaxSubqueryRows(int) - Method in class org.apache.druid.query.QueryContext
- getMaxTaskStatuses() - Method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- getMaxTime() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getMaxTime() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
- getMaxTime() - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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
-
Metadata-only operation that returns an upper bound on
ColumnHolder.TIME_COLUMN_NAME
values for this adapter. - getMaxTime() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getMaxTimeMillis() - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
- getMaxTotalRows() - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- getMaxTotalRowsOr(long) - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
-
Get the given maxTotalRows or the default.
- getMaxValue() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- getMaxValue() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getMaxValue() - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
- getMaxValue() - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- getMaxValue() - Method in class org.apache.druid.segment.DimensionDictionary
- 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() - Method in class org.apache.druid.segment.LongDimensionIndexer
- getMaxValue() - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- getMaxValue(String) - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getMaxValue(String) - Method in class org.apache.druid.segment.FilteredStorageAdapter
- getMaxValue(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
- getMaxValue(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
- 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
-
Returns the minimum value of the provided column, if known through an index, dictionary, or cache.
- getMaxValue(String) - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getMaxVectorSize() - Method in class org.apache.druid.frame.segment.columnar.FrameVectorCursor
- getMaxVectorSize() - Method in interface org.apache.druid.math.expr.Expr.VectorInputBindingInspector
- getMaxVectorSize() - Method in class org.apache.druid.query.filter.vector.BaseVectorValueMatcher
- getMaxVectorSize() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.MultiValueStringVectorObjectSelector
- getMaxVectorSize() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringMultiValueDimensionVectorSelector
- getMaxVectorSize() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringSingleValueDimensionVectorSelector
- getMaxVectorSize() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringVectorObjectSelector
- getMaxVectorSize() - Method in class org.apache.druid.segment.nested.VariantColumn.VariantVectorObjectSelector
- 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.ExpressionVectorInputBinding
- getMaxVectorSize() - Method in class org.apache.druid.segment.virtual.ExpressionVectorObjectSelector
- getMaxVectorSize() - Method in class org.apache.druid.segment.virtual.ExpressionVectorValueSelector
- getMaxVectorSize() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldVectorObjectSelector
- getMaxVectorSize() - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector
- getMean() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- getMemoryRequestServer() - Method in class org.apache.druid.segment.data.SafeWritableBase
- getMemoryStats() - Method in class org.apache.druid.java.util.metrics.cgroups.Memory.MemoryStat
- getMergedDimensions(List<IndexableAdapter>, DimensionsSpec) - Static method in interface org.apache.druid.segment.IndexMerger
- getMergedDimensionsFromQueryableIndexes(List<QueryableIndex>, DimensionsSpec) - Static method in interface org.apache.druid.segment.IndexMerger
- 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
- getMergingQueryRunnerMergeBuffer() - Method in class org.apache.druid.query.groupby.GroupByQueryResources
-
Returns a merge buffer associated with the
GroupByMergingQueryRunner
- getMessage() - Method in exception org.apache.druid.query.QueryException
- getMetadata() - Method in interface org.apache.druid.data.input.Committer
- getMetadata() - Method in class org.apache.druid.frame.segment.columnar.FrameQueryableIndex
- getMetadata() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getMetadata() - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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.SimpleQueryableIndex
- getMetadata() - Method in interface org.apache.druid.segment.StorageAdapter
- getMetadata() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getMetersMultiFactor() - Method in enum org.apache.druid.collections.spatial.search.RadiusBound.RadiusUnit
- getMethod() - Method in class org.apache.druid.audit.RequestInfo
- getMethod() - Method in class org.apache.druid.java.util.http.client.Request
- getMetric() - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- getMetric() - Method in class org.apache.druid.query.topn.NumericTopNMetricSpec
- getMetric(String) - Method in class org.apache.druid.data.input.ListBasedInputRow
- getMetric(String) - Method in class org.apache.druid.data.input.MapBasedRow
- getMetric(String) - Method in interface org.apache.druid.data.input.Row
-
Returns the metric column value for the given column name.
- getMetric(String) - Method in class org.apache.druid.query.MetricValueExtractor
- getMetric(String) - Method in class org.apache.druid.segment.transform.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.OnheapIncrementalIndex
- getMetricFloatValue(int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- 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.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.data.input.InputRowSchema
- 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
- getMetricObjectValue(int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- getMetricObjectValue(int, int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
- getMetrics() - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema
- getMetrics() - Method in class org.apache.druid.timeline.DataSegment
- getMetricsSpec() - Method in class org.apache.druid.timeline.CompactionState
- getMetricValues() - Method in class org.apache.druid.query.topn.DimValHolder
- getMin() - Method in class org.apache.druid.frame.processor.TournamentTree
-
Get the current minimum element (the overall winner, i.e., the run to pull the next element from in the K-way merge).
- getMinCardinalityToUseBitmapIndex() - Method in class org.apache.druid.query.filter.FilterTuning
- getMinCoordinates() - Method in class org.apache.druid.collections.spatial.ImmutableFloatNode
- getMinCoordinates() - Method in interface 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
- getMinHttpTimeoutMillis() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- getMinorVersion() - Method in class org.apache.druid.segment.ReferenceCountingSegment
- getMinorVersion() - Method in class org.apache.druid.timeline.DataSegment
- getMinorVersion() - Method in interface org.apache.druid.timeline.Overshadowable
- getMinorVersion() - Method in class org.apache.druid.timeline.partition.NumberedOverwritePartialShardSpec
- getMinorVersion() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- getMinorVersion() - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
Returns the minor version associated to the atomic update group which this segment belongs to.
- getMinTime() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getMinTime() - Method in class org.apache.druid.query.timeboundary.TimeBoundaryResultValue
- getMinTime() - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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
-
Metadata-only operation that returns a lower bound on
ColumnHolder.TIME_COLUMN_NAME
values for this adapter. - getMinTime() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getMinTimeMillis() - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
- 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.aggregation.AbstractSerializablePairLongObjectColumnHeader
- getMinValue() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- getMinValue() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getMinValue() - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
- getMinValue() - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- getMinValue() - Method in class org.apache.druid.segment.DimensionDictionary
- 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() - Method in class org.apache.druid.segment.LongDimensionIndexer
- getMinValue() - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- getMinValue(String) - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getMinValue(String) - Method in class org.apache.druid.segment.FilteredStorageAdapter
- getMinValue(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
- getMinValue(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
- 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
-
Returns the minimum value of the provided column, if known through an index, dictionary, or cache.
- getMinValue(String) - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getMissingSegments() - Method in class org.apache.druid.query.context.ResponseContext
- getMissingValue() - Method in class org.apache.druid.data.input.impl.TimestampSpec
- getModeNames() - Method in class org.apache.druid.math.expr.antlr.ExprLexer
- getModules() - Method in class org.apache.druid.guice.ExtensionsLoader
- 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
- getMovingAverages() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- getMultiValueFunction(String, Splitter) - Static method in class org.apache.druid.java.util.common.parsers.ParserUtils
- 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
- getMultiValueHandling() - Method in class org.apache.druid.data.input.impl.DimensionSchema
- getMultiValueRow(int) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
- getMultiValueRow(int) - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- getMultiValueRow(int) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- getMultiValueRow(int) - Method in class org.apache.druid.segment.nested.VariantColumn
- getName() - Method in class org.apache.druid.data.input.impl.DimensionSchema
- getName() - Method in class org.apache.druid.indexer.Property
- getName() - Method in class org.apache.druid.java.util.common.logger.Logger
- getName() - Method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- 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.ExpressionLambdaAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
- getName() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- getName() - Method in class org.apache.druid.query.ColumnSelectorPlus
- getName() - Method in class org.apache.druid.query.context.ResponseContext.AbstractKey
- getName() - Method in interface 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.
- getNestedColumnFormatVersion() - Method in class org.apache.druid.segment.DefaultColumnFormatConfig
- getNestedColumnMergeables(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexAdapter
- getNestedColumnMergeables(String) - Method in interface org.apache.druid.segment.IndexableAdapter
- getNestedColumnMergeables(String) - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
- getNestedFields() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getNestedFields() - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Get list of fields represented as a sequence of
NestedPathPart
- getNewValue() - Method in class org.apache.druid.metadata.MetadataCASUpdate
- getNext() - Method in class org.apache.druid.query.rowsandcols.util.FindResult
- getNextDirNameWithPrefixFromPath(String) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
-
Tries to parse out the most top level directory from the path.
- getNodes() - Method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- getNonEquiConditions() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
-
Return a list of non-equi-conditions (see class-level javadoc).
- getNoopRunnable() - Static method in class org.apache.druid.utils.Runnables
- getNormalizedBaseTableClauses() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
- getNormalizedJoinTableClauses() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
- getNullableStrategy() - Method in class org.apache.druid.segment.column.BaseTypeSignature
- getNullableStrategy() - Method in interface org.apache.druid.segment.column.TypeSignature
-
A
NullableTypeStrategy
is aTypeStrategy
which can handle reading and writing null values, at the very high cost of an additional byte per value, of which a single bit is used to storeNullHandling.IS_NULL_BYTE
orNullHandling.IS_NOT_NULL_BYTE
as appropriate. - getNullDimValue() - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- getNullDimValue() - Method in class org.apache.druid.segment.StringDimensionMergerV9
- getNullHandling() - Method in class org.apache.druid.query.extraction.StringFormatExtractionFn
- getNullProbability() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- getNullValues() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getNullVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalObjectVector
- getNullVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalVector
- 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
- getNullVector(String) - Method in interface org.apache.druid.math.expr.Expr.VectorInputBinding
- getNullVector(String) - Method in class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- getNumaMemoryStats() - Method in class org.apache.druid.java.util.metrics.cgroups.Memory.MemoryStat
- getNumBatchesProcessed() - Method in class org.apache.druid.indexer.report.KillTaskReport.Stats
- getNumBuckets() - Method in class org.apache.druid.query.operator.window.ranking.WindowPercentileProcessor
- getNumBuckets() - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- getNumBuckets() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- getNumBuckets() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- getNumBuckets() - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- getNumBuckets() - Method in class org.apache.druid.timeline.partition.PartitionBoundaries
- getNumBuckets() - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- getNumBytes() - Method in class org.apache.druid.segment.data.VSizeColumnarInts
- 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
- getNumBytesForDenseStorage() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getNumBytesForDenseStorage() - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getNumBytesForDenseStorage() - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- 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
- getNumConnections() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- getNumCorePartitions() - Method in interface org.apache.druid.timeline.partition.BucketNumberedShardSpec
- getNumCorePartitions() - Method in interface org.apache.druid.timeline.partition.BuildingShardSpec
- getNumCorePartitions() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- getNumCorePartitions() - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- getNumCorePartitions() - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- getNumCorePartitions() - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- getNumCorePartitions() - Method in interface org.apache.druid.timeline.partition.OverwriteShardSpec
-
The core partition concept is not used with segment locking.
- getNumCorePartitions() - Method in interface org.apache.druid.timeline.partition.ShardSpec
- getNumCorePartitions() - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- getNumDims() - Method in class org.apache.druid.collections.spatial.ImmutableFloatNode
- getNumDims() - Method in interface 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
- getNumericArrayFromObject(Object) - Static method in class org.apache.druid.frame.write.FrameWriterUtils
-
Retrieves a numeric list from a Java object, given that the object is an instance of something that can be returned from
BaseObjectColumnValueSelector.getObject()
of valid numeric array selectors representations WhileBaseObjectColumnValueSelector
specifies that only instances ofObject[]
can be returned from the numeric array selectors, this method also handles a few more cases which can be encountered if the selector is directly implemented on top of the group by stuff - getNumericSizeBytes() - Method in class org.apache.druid.frame.field.DoubleFieldWriter
- getNumericSizeBytes() - Method in class org.apache.druid.frame.field.FloatFieldWriter
- getNumericSizeBytes() - Method in class org.apache.druid.frame.field.LongFieldWriter
- getNumericSizeBytes() - Method in class org.apache.druid.frame.field.NumericFieldWriter
- getNumFrames() - Method in class org.apache.druid.frame.file.FrameFileFooter
- getNumHeaderBytes() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getNumHeaderBytes() - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getNumHeaderBytes() - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- getNumHeaderLinesToSkip() - Method in class org.apache.druid.data.input.impl.DelimitedValueReader
- getNumHeaderLinesToSkip() - Method in class org.apache.druid.data.input.impl.JsonLineReader
- getNumHeaderLinesToSkip() - Method in class org.apache.druid.data.input.impl.RegexReader
- getNumHeaderLinesToSkip() - Method in class org.apache.druid.data.input.TextReader
-
Returns the number of header lines to skip.
- getNumInitalBuffersForIntermediatePool() - Method in class org.apache.druid.query.DruidProcessingConfig
- getNumLookupLoadingThreads() - Method in class org.apache.druid.query.lookup.LookupConfig
- getNumMergeBuffers() - Method in class org.apache.druid.query.DruidProcessingConfig
- getNumMergingQueryRunnerMergeBuffers() - Method in class org.apache.druid.query.groupby.GroupByQueryResources
-
Returns the number of the currently unused merge buffers reserved for
GroupByMergingQueryRunner
- getNumMetrics() - Method in class org.apache.druid.segment.TimeAndDimsPointer
- getNumNonZeroRegisters() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getNumNonZeroRegisters() - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getNumNonZeroRegisters() - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- getNumObjects() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- getNumParallelCombineThreads() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- getNumPartitions() - Method in class org.apache.druid.frame.file.FrameFileFooter
- getNumReferences() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
- getNumRetriesOnMissingSegments(int) - Method in class org.apache.druid.query.QueryContext
- getNumRows() - Method in class org.apache.druid.frame.segment.columnar.FrameQueryableIndex
- getNumRows() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getNumRows() - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriter
- getNumRows() - Method in interface org.apache.druid.frame.write.FrameWriter
-
Returns the number of rows written so far.
- getNumRows() - Method in class org.apache.druid.frame.write.RowBasedFrameWriter
- getNumRows() - Method in interface org.apache.druid.query.filter.ColumnIndexSelector
- getNumRows() - Method in class org.apache.druid.query.metadata.metadata.SegmentAnalysis
- getNumRows() - Method in class org.apache.druid.segment.ColumnSelectorColumnIndexSelector
- getNumRows() - Method in class org.apache.druid.segment.FilteredStorageAdapter
- 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.SchemaPayloadPlus
- getNumRows() - Method in class org.apache.druid.segment.SegmentMetadata
- getNumRows() - Method in class org.apache.druid.segment.serde.NullColumnPartSerde
- getNumRows() - Method in class org.apache.druid.segment.SimpleQueryableIndex
- getNumRows() - Method in interface org.apache.druid.segment.StorageAdapter
- getNumRows() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getNumRows() - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- getNumSegmentsKilled() - Method in class org.apache.druid.indexer.report.KillTaskReport.Stats
- getNumSegmentsMarkedAsUnused() - Method in class org.apache.druid.indexer.report.KillTaskReport.Stats
- getNumShards() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- getNumThreads() - 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
- getObj() - Method in class org.apache.druid.java.util.http.client.response.ClientResponse
- getObject() - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
- getObject() - Method in class org.apache.druid.query.aggregation.cardinality.HyperLogLogCollectorAggregateCombiner
- getObject() - Method in class org.apache.druid.query.aggregation.firstlast.first.GenericFirstAggregateCombiner
- getObject() - Method in class org.apache.druid.query.aggregation.firstlast.last.GenericLastAggregateCombiner
- 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
-
Returns the currently-selected object.
- 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 class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- 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.BaseExpressionColumnValueSelector
- getObject() - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
- getObject() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- getObject() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector
- getObject() - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- getObject() - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- getObject() - Method in class org.apache.druid.timeline.partition.LinearPartitionChunk
- getObject() - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- getObject() - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- getObject() - Method in interface org.apache.druid.timeline.partition.PartitionChunk
-
Returns the payload, generally an object that can be used to perform some action against the shard.
- getObject() - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- getObject() - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- getObject() - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- getObject() - Method in class org.apache.druid.timeline.TimelineObjectHolder
- getObject(int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- getObject(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.DoubleColumnAccessorBase
- getObject(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.FloatColumnAccessorBase
- getObject(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.LongColumnAccessorBase
- getObject(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- getObject(int) - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Get the
Object
representation of the row. - getObject(int) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- getObject(int) - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix.MatrixRow
- getObject(long, long) - Method in interface org.apache.druid.storage.remote.ChunkingStorageConnector.GetObjectFromRangeFunction
- getObjectGlob() - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- getObjectOpenFunction() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- getObjects() - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- getObjects() - Method in class org.apache.druid.query.rowsandcols.column.ObjectArrayColumn
-
Gets the underlying object array.
- getObjectSize(CloudObjectLocation) - Method in interface org.apache.druid.data.input.impl.CloudObjectSplitWidget
-
Size of an object.
- getObjectStrategy() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
- getObjectStrategy() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexMetricSerde
- getObjectStrategy() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexMetricSerde
- getObjectStrategy() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexMetricSerde
- getObjectStrategy() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexMetricSerde
- 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.DictionaryEncodedColumnMerger
- getObjectStrategy() - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- getObjectStrategy() - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
-
Deprecated.
- getObjectStrategy() - Method in class org.apache.druid.segment.StringDimensionMergerV9
- getObjectSupplier() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- getObjectVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalDoubleVector
- getObjectVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalLongVector
- getObjectVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalObjectVector
- getObjectVector() - Method in class org.apache.druid.math.expr.vector.ExprEvalVector
- getObjectVector() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.MultiValueStringVectorObjectSelector
- getObjectVector() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringVectorObjectSelector
- getObjectVector() - Method in class org.apache.druid.segment.nested.VariantColumn.VariantVectorObjectSelector
- 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
- getObjectVector() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldVectorObjectSelector
- getObjectVector(String) - Method in interface org.apache.druid.math.expr.Expr.VectorInputBinding
- getObjectVector(String) - Method in class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- getOffset() - Method in class org.apache.druid.frame.segment.FrameFilteredOffset
- 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.query.operator.OffsetLimit
- getOffset() - Method in class org.apache.druid.query.operator.window.value.WindowOffsetProcessor
- 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.ImmutableFloatNode
- getOffsetFromInitial() - Method in interface org.apache.druid.collections.spatial.ImmutableNode
- getOffsetLimit() - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- getOffsetLimit() - Method in class org.apache.druid.query.scan.ScanQuery
- 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.
- getOldValue() - Method in class org.apache.druid.metadata.MetadataCASUpdate
- getOnlyElement(I, Function<? super I, ? extends X>) - Static method in class org.apache.druid.utils.CollectionUtils
-
Like
Iterables.getOnlyElement(Iterable)
, but allows a customizable error message. - getOp() - Method in class org.apache.druid.query.operator.join.JoinPartDefn
- getOperators() - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- getOrder() - Method in class org.apache.druid.frame.key.RunLengthEntry
- getOrder() - Method in class org.apache.druid.query.scan.ScanQuery.OrderBy
- getOrderBy() - Method in class org.apache.druid.query.operator.window.WindowFrame
- getOrderByColNames() - Method in class org.apache.druid.query.operator.window.WindowFrame
- getOrderByForDimName(List<OrderByColumnSpec>, String) - Static method in class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- getOrderBys() - Method in class org.apache.druid.query.scan.ScanQuery
- 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.operator.ScanOperatorFactory
- 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
- getOrigin() - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- getOrigin() - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- 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.OnheapIncrementalIndex
- getOutputBytes() - Static method in class org.apache.druid.segment.CompressedPools
- getOutputColumn() - Method in class org.apache.druid.query.operator.window.ranking.WindowPercentileProcessor
- getOutputColumn() - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- getOutputColumn() - Method in class org.apache.druid.query.operator.window.ranking.WindowRowNumberProcessor
- getOutputColumn() - Method in class org.apache.druid.query.operator.window.value.WindowValueProcessorBase
- getOutputName() - Method in class org.apache.druid.frame.util.SettableLongVirtualColumn
- 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 class org.apache.druid.segment.virtual.FallbackVirtualColumn
- getOutputName() - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- getOutputName() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- getOutputName() - Method in interface org.apache.druid.segment.VirtualColumn
-
Output name of this column.
- getOutputRows() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
-
Total number of output 'rows' produced by merging and combining the set of input
Sequence
s - getOutputsFileNameForPath(String, int, int, String, String) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
-
Fetches the file location where a particular worker writes the data corresponding to a particular stage and a custom path name
- getOutputType() - Method in class org.apache.druid.math.expr.vector.BivariateFunctionVectorProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.CastToDoubleVectorProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.CastToLongVectorProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.CastToStringVectorProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.DoubleOutDoubleInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.DoubleOutDoubleLongInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.DoubleOutDoublesInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.DoubleOutLongDoubleInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.DoubleOutLongInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.DoubleOutLongsInFunctionVectorValueProcessor
- getOutputType() - Method in interface org.apache.druid.math.expr.vector.ExprVectorProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.LongOutDoubleInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.LongOutDoubleLongInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.LongOutDoublesInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.LongOutLongDoubleInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.LongOutLongInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.LongOutLongsInFunctionVectorValueProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.LongOutObjectInFunctionVectorProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.LongOutObjectsInFunctionVectorProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.ObjectOutMultiObjectInVectorProcessor
- getOutputType() - Method in class org.apache.druid.math.expr.vector.ObjectOutObjectsInFunctionVectorProcessor
- getOutputType() - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
- 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() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
The output type of the original expression.
- getOutputType() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- getOutputType(Expr.InputBindingInspector) - Method in interface org.apache.druid.math.expr.Expr
-
Given an
Expr.InputBindingInspector
, compute what the outputExpressionType
will be for this expression. - getOutputType(Expr.InputBindingInspector) - Method in class org.apache.druid.query.expression.TimestampExtractExprMacro.TimestampExtractDynamicExpr
- getOutputType(Expr.InputBindingInspector) - Method in class org.apache.druid.query.expression.TimestampExtractExprMacro.TimestampExtractExpr
- getOutputType(Expr.InputBindingInspector) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorDynamicExpr
- getOutputType(Expr.InputBindingInspector) - Method in class org.apache.druid.query.expression.TimestampFloorExprMacro.TimestampFloorExpr
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayAddElementFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayConstructorFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayLengthFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayOffsetFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayOffsetOfFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayOrdinalFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayOrdinalOfFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraySliceFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraysMergeFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayToStringFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseComplement
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseConvertDoubleToLongBits
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BitwiseConvertLongBitsToDouble
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BivariateBitwiseMathFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.BivariateMathFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CaseSearchedFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CaseSimpleFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CastFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.CoalesceFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ConcatFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ConditionFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Div
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.DoubleBivariateMathFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.DoubleUnivariateMathFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.GetExponent
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in interface org.apache.druid.math.expr.Function
-
Compute the output type of this function for a given set of argument expression inputs.
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsDistinctFromFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsFalseFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotDistinctFromFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotFalseFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotNullFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotTrueFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNullFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsTrueFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.LeftFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.LowerFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.LpadFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ParseLong
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Pi
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ReduceFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.RepeatFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ReplaceFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ReverseFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.RightFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Round
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.RpadFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.SafeDivide
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.ScalarInArrayFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.Scalb
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.SizeFormatFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.StringFormatFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.StringToArrayFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.StrlenFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.StrposFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.SubMonthFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.SubstringFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.TimestampFromEpochFunc
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.UnivariateMathFunction
- getOutputType(Expr.InputBindingInspector, List<Expr>) - Method in class org.apache.druid.math.expr.Function.UpperFunc
- getOutputType(Expr.InputBindingInspector, LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.BaseFoldFunction
- getOutputType(Expr.InputBindingInspector, LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.BaseMapFunction
- getOutputType(Expr.InputBindingInspector, LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.FilterFunction
- getOutputType(Expr.InputBindingInspector, LambdaExpr, List<Expr>) - Method in interface org.apache.druid.math.expr.ApplyFunction
-
Compute the output type of this function for a given lambda and the argument expressions which will be applied as its inputs.
- getOutputType(Expr.InputBindingInspector, LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.MatchFunction
- getOvershadowed() - Method in class org.apache.druid.timeline.partition.PartitionHolder
- getParallelism() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
-
Total number of layer 1 parallel tasks (+ 1 for total number of concurrent tasks for this query)
- getParallelMergeInitialYieldRows(int) - Method in class org.apache.druid.query.QueryContext
- getParallelMergeParallelism(int) - Method in class org.apache.druid.query.QueryContext
- getParallelMergeSmallBatchRows(int) - Method in class org.apache.druid.query.QueryContext
- getParams() - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriExtractor
- 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.data.input.InputRowListPlusRawValues
- getParseException() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
- getParseSpec() - Method in interface org.apache.druid.data.input.impl.InputRowParser
-
Deprecated.
- getParseSpec() - Method in class org.apache.druid.data.input.impl.MapInputRowParser
- getParseSpec() - Method in class org.apache.druid.data.input.impl.NoopInputRowParser
- getParseSpec() - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- getParseSpec() - Method in class org.apache.druid.segment.transform.TransformingInputRowParser
- getPartialIndex() - Method in class org.apache.druid.query.filter.FilterBundle.MatcherBundleInfo
- getPartIdentifier() - Method in class org.apache.druid.segment.nested.NestedPathArrayElement
- getPartIdentifier() - Method in class org.apache.druid.segment.nested.NestedPathField
- getPartIdentifier() - Method in interface org.apache.druid.segment.nested.NestedPathPart
- getPartitionColumns() - Method in class org.apache.druid.query.operator.NaivePartitioningOperatorFactory
- getPartitionDimension() - Method in class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
- getPartitionDimension() - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- getPartitionDimensions() - Method in interface org.apache.druid.indexer.partitions.DimensionBasedPartitionsSpec
- getPartitionDimensions() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- getPartitionDimensions() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- getPartitionDimensions() - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- getPartitionDimensions() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- getPartitionDimensions() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- getPartitionDimensions() - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- getPartitionFunction() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- getPartitionFunction() - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- getPartitionFunction() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- getPartitionFunction() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- getPartitionFunction() - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- getPartitionHolder() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline.TimelineEntry
- getPartitionNum() - Method in interface org.apache.druid.timeline.partition.BucketNumberedShardSpec
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- getPartitionNum() - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
Returns the partition ID of this segment.
- getPartitionNum() - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- getPartitionNum() - Method in class org.apache.druid.timeline.SegmentId
- getPartitionNumber() - Method in class org.apache.druid.frame.processor.OutputChannel
- getPartitionNumber() - Method in class org.apache.druid.query.SegmentDescriptor
- getPartitionNumbers() - Method in class org.apache.druid.frame.processor.OutputChannels
-
Returns the set of partition numbers that appear across all channels.
- getPartitionOutputsFileNameWithPathForPartition(String, int, int, String, int) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
-
Fetches the file location where a particular worker writes the data corresponding to a particular stage and partition
- getPartitionsSpec() - Method in class org.apache.druid.timeline.CompactionState
- getPartitionStartFrame(int) - Method in class org.apache.druid.frame.file.FrameFile
-
First frame of a given partition.
- getPartitionStartFrame(int) - Method in class org.apache.druid.frame.file.FrameFileFooter
-
First frame of a given partition.
- getParts() - Method in class org.apache.druid.segment.column.ColumnDescriptor
- getPassword() - Method in class org.apache.druid.java.util.http.client.HttpClientProxyConfig
- getPassword() - Method in class org.apache.druid.metadata.DefaultPasswordProvider
- getPassword() - Method in class org.apache.druid.metadata.EnvironmentVariablePasswordProvider
- getPassword() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- getPassword() - Method in interface org.apache.druid.metadata.PasswordProvider
-
Deprecated.
- getPassword() - Method in interface org.apache.druid.metadata.PasswordProviderRedactionMixIn
- getPath() - Method in class org.apache.druid.data.input.impl.CloudObjectLocation
- getPath() - Method in class org.apache.druid.data.input.impl.HttpEntity
- getPath() - Method in class org.apache.druid.data.input.RetryingInputEntity
-
Get path name for this entity, used by the default implementation of
RetryingInputEntity.open()
to determine if the underlying stream needs decompressed, based on file extension of the path - getPathForHadoop() - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
- getPathForHadoop() - Method in class org.apache.druid.segment.loading.NoopDataSegmentPusher
- getPathForHadoop(String) - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
-
Deprecated.
- getPathForHadoop(String) - Method in class org.apache.druid.segment.loading.NoopDataSegmentPusher
-
Deprecated.
- getPathParts() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- getPattern() - Method in class org.apache.druid.data.input.impl.RegexInputFormat
- getPattern() - Method in class org.apache.druid.data.input.impl.RegexParseSpec
- 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
- getPayload() - Method in class org.apache.druid.audit.AuditEntry
-
Non-null payload of the audit event.
- getPayload() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrorsTaskReport
- getPayload() - Method in class org.apache.druid.indexer.report.KillTaskReport
- getPayload() - Method in class org.apache.druid.indexer.report.TaskContextReport
- getPayload() - Method in interface org.apache.druid.indexer.report.TaskReport
- getPayloadBytePosition() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getPayloadBytePosition() - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getPayloadBytePosition() - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- getPayloadBytePosition(ByteBuffer) - Method in class org.apache.druid.hll.HyperLogLogCollector
- getPayloadBytePosition(ByteBuffer) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getPayloadBytePosition(ByteBuffer) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- getPayloadFromTaskReports(Map<String, TaskReport>) - Static method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- getPeerType() - Method in class org.apache.druid.query.operator.window.WindowFrame
- getPendingRequests() - Method in interface org.apache.druid.collections.BlockingPool
-
Returns the count of the requests waiting to acquire a batch of resources.
- getPendingRequests() - Method in class org.apache.druid.collections.DefaultBlockingPool
- getPendingRequests() - Method in class org.apache.druid.collections.DummyBlockingPool
- getPendingSegmentsTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getPeriod() - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- getPeriodUs() - Method in class org.apache.druid.java.util.metrics.cgroups.Cpu.CpuAllocationMetric
- getPid() - Method in class org.apache.druid.java.util.metrics.JvmPidDiscoverer
-
Returns the PID as a best guess.
- getPid() - Method in interface org.apache.druid.java.util.metrics.PidDiscoverer
- getPid() - Method in class org.apache.druid.java.util.metrics.SigarPidDiscoverer
- getPipeline() - Method in class org.apache.druid.java.util.http.client.netty.HttpClientPipelineFactory
- 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.
- getPollDuration() - Method in class org.apache.druid.common.config.ConfigManagerConfig
- getPool() - Method in class org.apache.druid.guice.LifecycleForkJoinPoolProvider
- getPoolCacheInitialCount() - Method in class org.apache.druid.query.DruidProcessingBufferConfig
- getPoolCacheMaxCount() - Method in class org.apache.druid.query.DruidProcessingBufferConfig
- getPoolSize() - Method in class org.apache.druid.collections.DefaultBlockingPool
- getPort() - Method in class org.apache.druid.indexer.TaskLocation
- getPort() - Method in class org.apache.druid.java.util.http.client.HttpClientProxyConfig
- getPort() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- getPosition() - Method in exception org.apache.druid.frame.write.InvalidNullByteException
- getPosition() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- 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
- getPostJoinFilter() - Method in class org.apache.druid.segment.join.PostJoinCursor
- getPostJoinVirtualColumns() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysis
- 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.
- getPrefixes() - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- 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
- getPriorIndex(IncrementalIndexRow) - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
- getPriority() - Method in class org.apache.druid.query.AbstractPrioritizedCallable
- getPriority() - Method in class org.apache.druid.query.AbstractPrioritizedQueryRunnerCallable
- getPriority() - Method in interface org.apache.druid.query.PrioritizedCallable
- getPriority() - Method in interface org.apache.druid.query.PrioritizedRunnable
- getPriority() - Method in class org.apache.druid.query.QueryContext
- getPriority(int) - Method in class org.apache.druid.query.QueryContext
- 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
- getProcessed() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- getProcessedBytes() - Method in interface org.apache.druid.data.input.InputStats
- getProcessedBytes() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
- getProcessedBytes() - Method in class org.apache.druid.segment.incremental.RowIngestionMetersTotals
- getProcessedBytes() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- 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
- getProcessedWithError() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- getProcessor() - Method in class org.apache.druid.query.operator.window.WindowOperatorFactory
- getProcessorCount() - Method in class org.apache.druid.java.util.metrics.ProcFsReader
-
Reads the cpuinfo path (example in src/test/resources/cpuinfo) and counts the number of processors.
- getProcessors() - Method in class org.apache.druid.query.operator.window.ComposingProcessor
- getProgressDigest() - Method in class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- getProjectedColumns() - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- getProjectFields() - Method in class org.apache.druid.query.operator.join.JoinPartDefn
- getProperty(Properties, String) - Static method in class org.apache.druid.common.utils.PropUtils
- getPropertyAsInt(Properties, String) - Static method in class org.apache.druid.common.utils.PropUtils
- getPropertyAsInt(Properties, String, Integer) - Static method in class org.apache.druid.common.utils.PropUtils
- getPropertyKeys(Object) - Method in class org.apache.druid.data.input.impl.FastJacksonJsonNodeJsonProvider
- getProxyConfig() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- 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
- getQueryableIndex() - Method in class org.apache.druid.segment.QueryableIndexIndexableAdapter
- 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
- getQueryParams() - Method in class org.apache.druid.audit.RequestInfo
- getQueryResourceId() - Method in class org.apache.druid.query.QueryContext
- getQueryResultsFileNameWithPathForPartition(String, int, int, String, int) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
- getQueryResultsForTaskIdFolderName(String, int, int, String) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
- getQueryResultsSuccessFilePath(String, int, int) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
- 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
- getQueueInsertionTime() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getQueueSize() - Method in class org.apache.druid.query.PrioritizedExecutorService
- getQuotaUs() - Method in class org.apache.druid.java.util.metrics.cgroups.Cpu.CpuAllocationMetric
- getRadius() - Method in class org.apache.druid.collections.spatial.search.RadiusBound
- getRadiusUnit() - Method in class org.apache.druid.collections.spatial.search.RadiusBound
- getRandomId() - Static method in class org.apache.druid.common.utils.IdUtils
- getRandomIdWithPrefix(String) - Static method in class org.apache.druid.common.utils.IdUtils
- getRange(long, int) - Method in class org.apache.druid.segment.data.CompressedBlockReader
-
Get
ByteBuffer
containing data from starting offset of contiguous virtual address range of the specified size. - getRange(T, boolean, T, boolean) - Method in class org.apache.druid.segment.data.FixedIndexed
- getRaw(int) - Method in class org.apache.druid.data.input.ListBasedInputRow
- getRaw(String) - Method in class org.apache.druid.data.input.ListBasedInputRow
- getRaw(String) - Method in class org.apache.druid.data.input.MapBasedRow
- getRaw(String) - Method in interface org.apache.druid.data.input.Row
-
Returns the raw dimension value for the given column name.
- getRaw(String) - Method in class org.apache.druid.segment.transform.TransformedInputRow
- getRawTimestamp(Map<String, Object>) - Method in class org.apache.druid.data.input.impl.TimestampSpec
- getRawValues() - Method in class org.apache.druid.data.input.InputRowListPlusRawValues
-
This method is left here only for test cases
- getRawValuesList() - Method in class org.apache.druid.data.input.InputRowListPlusRawValues
- getReadableChannel() - Method in class org.apache.druid.frame.processor.OutputChannel
-
Returns the readable channel of this pair.
- getReadableChannelSupplier() - Method in class org.apache.druid.frame.processor.OutputChannel
- getReadableChannelSupplier() - Method in class org.apache.druid.frame.processor.PartitionedOutputChannel
-
Returns the partitioned readable channel supplier of this pair.
- getReadableFrameChannel(int) - Method in class org.apache.druid.frame.channel.DurableStoragePartitionedReadableFrameChannel
- getReadableFrameChannel(int) - Method in interface org.apache.druid.frame.channel.PartitionedReadableFrameChannel
-
Allows reading a particular partition in the channel
- getReadableVectorInspector() - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
- getReadableVectorInspector() - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
-
Returns a
ReadableVectorInspector
for theVectorCursor
that generated this object. - getReader(ByteBuffer, ByteOrder) - Method in enum org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
- getReadTimeout() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- getRealRAC() - Method in class org.apache.druid.query.rowsandcols.StorageAdapterRowsAndColumns
- getReason() - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
- getReasonOfNotAdded() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
- getRecipientBaseUrl() - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig
- getRecipientBaseUrlPattern() - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitterConfig
- getRecordsProcessed() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- getRegionOffset() - Method in class org.apache.druid.segment.data.SafeWritableBase
- getRegionOffset(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getRegisterOffset() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getRegisterOffset() - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getRegisterOffset() - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- getRegrowthThreshold() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- getReleaseSize() - Method in class org.apache.druid.query.operator.join.JoinConfig
- getRemaining() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getRemainingResponses() - Method in class org.apache.druid.query.context.ResponseContext
- 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
- getReplicationFactor() - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- getReportKey() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrorsTaskReport
- getReportKey() - Method in class org.apache.druid.indexer.report.KillTaskReport
- getReportKey() - Method in class org.apache.druid.indexer.report.TaskContextReport
- getReportKey() - Method in interface org.apache.druid.indexer.report.TaskReport
- getRequest() - Method in class org.apache.druid.audit.AuditEntry
-
Details of the REST API request associated with this audit, if any.
- getRequiredBindings() - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Get the set of required column inputs to evaluate an expression (
IdentifierExpr.binding
) - getRequiredBindingsList() - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Get the list of required column inputs to evaluate an expression (
IdentifierExpr.binding
) - getRequiredColumns() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Deprecated.
- getRequiredColumns() - Method in class org.apache.druid.query.filter.AndDimFilter
- getRequiredColumns() - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- 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.EqualityFilter
- 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.IsBooleanDimFilter
- 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.NullFilter
- getRequiredColumns() - Method in class org.apache.druid.query.filter.OrDimFilter
- getRequiredColumns() - Method in class org.apache.druid.query.filter.RangeFilter
- 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.query.filter.TypedInFilter
- getRequiredColumns() - Method in class org.apache.druid.query.groupby.GroupByQuery
- getRequiredColumns() - Method in interface org.apache.druid.query.Query
-
Returns the set of columns that this query will need to access out of its datasource.
- getRequiredColumns() - Method in class org.apache.druid.query.scan.ScanQuery
- getRequiredColumns() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
- getRequiredColumns() - Method in class org.apache.druid.query.topn.TopNQuery
- 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.IsBooleanFilter
- 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
- getRequiredColumns() - Method in class org.apache.druid.segment.join.JoinConditionAnalysis
-
Returns the set of column names required by this join condition.
- getRequiredColumns() - Method in class org.apache.druid.segment.transform.ExpressionTransform
- getRequiredColumns() - Method in interface org.apache.druid.segment.transform.Transform
-
Returns the names of all columns that this transform is going to read.
- getRequiredColumns() - Method in class org.apache.druid.segment.transform.TransformSpec
- getResource(Object, String) - Static method in class org.apache.druid.java.util.common.StringUtils
- getResource(String) - Method in class org.apache.druid.guice.ExtensionFirstClassLoader
- getResources(String) - Method in class org.apache.druid.guice.ExtensionFirstClassLoader
- getResourceType() - Method in interface org.apache.druid.storage.ExportStorageProvider
- getResourceType() - Method in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- getResponse() - Method in class org.apache.druid.java.util.http.client.response.FullResponseHolder
- 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 usesOrdering.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)
andQueryRunnerFactory.mergeRunners(QueryProcessingPool, 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
-
Equivalent to
getResultRowSignature(Finalization.UNKNOWN)
. - getResultRowSignature(RowSignature.Finalization) - Method in class org.apache.druid.query.groupby.GroupByQuery
-
Returns a result row signature, 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
- getResultType() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Get the
ColumnType
for the final form of this aggregator, i.e. - getResultType() - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
-
actual type is
HistogramVisual
- getResultType() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.SingleValueAggregatorFactory
- getResultType() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- 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.operator.WindowOperatorQueryQueryToolChest
- 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
- getRetryCondition() - Method in class org.apache.druid.data.input.BytesCountingInputEntity
- getRetryCondition() - Method in class org.apache.druid.data.input.impl.HttpEntity
- getRetryCondition() - Method in interface org.apache.druid.data.input.InputEntity
-
Returns a retry condition that the caller should retry on.
- getRetryCondition() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- getReverseBitmapOffsetIterator(ImmutableBitmap) - Static method in class org.apache.druid.segment.BitmapOffset
- getReverseId(int) - Method in class org.apache.druid.segment.IdMapping
-
Get the original index, given the substitute
- getRewriteConfig() - Method in class org.apache.druid.segment.join.filter.JoinFilterPreAnalysisKey
- getRhs() - Method in class org.apache.druid.collections.SerializablePair
- 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
- getRootField(JsonNode, String) - Method in class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- getRootField(T, String) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
-
Get a top level field from a "json" object
- getRow() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
- getRow() - Method in class org.apache.druid.segment.ConstantDimensionSelector
- getRow() - Method in class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- getRow() - Method in interface org.apache.druid.segment.DimensionSelector
-
Returns the indexed values at the current position in this DimensionSelector.
- getRow() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.InputRowHolder
- 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.SingleStringInputDeferredEvaluationExpressionDimensionSelector
-
Get the underlying selector
IndexedInts
row - getRow(int) - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix
- getRow(int) - Method in class org.apache.druid.segment.ConstantDimensionSelector
- getRow(int) - Method in class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- getRow(int) - Method in interface org.apache.druid.segment.historical.HistoricalDimensionSelector
- 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.
- getRowId() - Method in class org.apache.druid.frame.segment.row.FrameColumnSelectorFactory
- getRowId() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.InputRowHolder
- getRowId() - Method in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
- getRowId() - Method in interface org.apache.druid.segment.RowIdSupplier
-
Returns a number that uniquely identifies the current position of some underlying cursor.
- getRowIdSupplier() - Method in class org.apache.druid.frame.segment.row.FrameColumnSelectorFactory
- getRowIdSupplier() - Method in class org.apache.druid.query.scan.SettableCursorColumnSelectorFactory
-
Since we don't know all the cursors beforehand, we can't reconcile their row id suppliers to provide one here
- getRowIdSupplier() - Method in interface org.apache.druid.segment.ColumnSelectorFactory
-
Returns a
RowIdSupplier
that allows callers to detect whether the selectors returned by this factory have moved or not. - getRowIdSupplier() - Method in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
- getRowIdSupplier() - Method in class org.apache.druid.segment.RowBasedColumnSelectorFactory
- getRowIdSupplier() - Method in class org.apache.druid.segment.virtual.VirtualizedColumnSelectorFactory
- getRowIndex() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRow
- getRowNum() - Method in class org.apache.druid.segment.RowPointer
- getRowNumber() - Method in exception org.apache.druid.frame.write.InvalidFieldException
- getRowNumber() - Method in exception org.apache.druid.frame.write.InvalidNullByteException
- 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
- getRowsAsList() - Method in class org.apache.druid.query.InlineDataSource
-
Returns rows as a list.
- getRowsAsSequence() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- getRowScanCount() - Method in class org.apache.druid.query.context.ResponseContext
- 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
-
Used by
HeapBasedTopNAlgorithm
. - getRowSignature() - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- getRowSignature() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- getRowSignature() - Method in class org.apache.druid.query.FrameSignaturePair
- getRowSignature() - Method in class org.apache.druid.query.InlineDataSource
-
Returns the row signature (map of column name to type) for this inline datasource.
- getRowSignature() - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- getRowSignature() - Method in class org.apache.druid.query.scan.ScanQuery
-
Returns the RowSignature.
- getRowSignature() - Method in class org.apache.druid.query.scan.ScanResultValue
- getRowSignature() - Method in class org.apache.druid.segment.RowBasedStorageAdapter
- getRowSignature() - Method in class org.apache.druid.segment.SchemaPayload
- getRowSignature() - Method in interface org.apache.druid.segment.StorageAdapter
-
Returns the row signature of the data available from this adapter.
- getRowSignature(boolean) - Method in class org.apache.druid.query.scan.ScanQuery
- getRowSize() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- getRowStats() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- getRowValue(int) - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexColumn
- getRowValue(int) - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn
- getRowValue(int) - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn
- getRowValue(int) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn
- 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
- getRowValue(int) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getRowVector() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringMultiValueDimensionVectorSelector
- getRowVector() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringSingleValueDimensionVectorSelector
- 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.
- getRowVector() - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector
- getRTree() - Method in interface org.apache.druid.segment.index.semantic.SpatialIndex
- getRuleIndex() - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExprContext
- getRuleIndex() - Method in class org.apache.druid.math.expr.antlr.ExprParser.FnArgsContext
- getRuleIndex() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LambdaContext
- getRuleIndex() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LiteralElementContext
- getRuleIndex() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongElementContext
- getRuleIndex() - Method in class org.apache.druid.math.expr.antlr.ExprParser.NumericElementContext
- getRuleIndex() - Method in class org.apache.druid.math.expr.antlr.ExprParser.StartContext
- getRuleIndex() - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringElementContext
- getRuleNames() - Method in class org.apache.druid.math.expr.antlr.ExprLexer
- getRuleNames() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- getRulesTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getRunLength() - Method in class org.apache.druid.frame.key.RunLengthEntry
- getRunLengthEntries() - Method in class org.apache.druid.frame.key.RowKeyComparisonRunLengths
- getRunner() - Method in class org.apache.druid.query.AbstractPrioritizedQueryRunnerCallable
- getRunner() - Method in interface org.apache.druid.query.PrioritizedQueryRunnerCallable
-
This method can be used by the extensions to get the runner that the given query execution task corresponds to.
- 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.
- getRunnerStatusCode() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getRuntimeInfo() - Static method in class org.apache.druid.utils.JvmUtils
- getSavedParseExceptionReports() - Method in class org.apache.druid.segment.incremental.ParseExceptionHandler
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayConstructorFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayLengthFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayScalarFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraysFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraySliceFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.CastFunc
- getScalarInputs(List<Expr>) - Method in interface org.apache.druid.math.expr.Function
-
Given a list of arguments to this
Function
, get the set of arguments that must evaluate to a scalar value - getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- getScalarInputs(List<Expr>) - Method in class org.apache.druid.math.expr.Function.StringToArrayFunction
- 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".
- getSchedulerClassName() - Method in class org.apache.druid.java.util.metrics.DruidMonitorSchedulerConfig
- getSchema() - Method in class org.apache.druid.segment.generator.ColumnValueGenerator
- getSchema(String) - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- getSchemaCount() - Method in class org.apache.druid.segment.SegmentSchemaMapping
- getSchemaFingerprint() - Method in class org.apache.druid.segment.SegmentMetadata
- getSchemaFingerprintToPayloadMap() - Method in class org.apache.druid.segment.SegmentSchemaMapping
- getSchemaPayload() - Method in class org.apache.druid.segment.SchemaPayloadPlus
- getSchemaVersion() - Method in class org.apache.druid.segment.SegmentSchemaMapping
- getSearchQuerySpec() - Method in class org.apache.druid.query.extraction.SearchQuerySpecDimExtractionFn
- getSearchStrategy() - Method in class org.apache.druid.query.search.SearchQueryConfig
- getSegmentAvailabilityWaitTimeMs() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- 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
- getSegmentIdToMetadataMap() - Method in class org.apache.druid.segment.SegmentSchemaMapping
- getSegmentLoader() - Method in class org.apache.druid.segment.IndexSpec
- getSegments() - Method in class org.apache.druid.segment.DataSegmentsWithSchemas
- getSegmentSchemaMapping() - Method in class org.apache.druid.segment.DataSegmentsWithSchemas
- getSegmentSchemaMetadata() - Method in class org.apache.druid.segment.DataSegmentWithMetadata
- getSegmentSchemasTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getSegmentsForIntervals(DataSource, Iterable<Interval>) - Method in interface org.apache.druid.segment.SegmentWrangler
-
Gets Segments for a particular datasource and set of intervals.
- getSegmentsPublished() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- getSegmentsRead() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- getSegmentsTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- 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 class org.apache.druid.query.filter.FilterBundle.IndexBundleInfo
- 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
- getSequenceCount(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Gets the number of blocks of 1's or 0's stored in a sequence word
- getSequenceNumWords(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- getSerdeForType(String) - Static method in class org.apache.druid.segment.serde.ComplexMetrics
- getSerializableObject() - Method in class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
-
Returns a Map to be used for serializing objects of this class.
- getSerializableObject() - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- getSerializableObject() - Method in class org.apache.druid.timeline.partition.PartitionBoundaries
- getSerializableObject() - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
-
Returns a Map to be used for serializing objects of this class.
- getSerializedATN() - Method in class org.apache.druid.math.expr.antlr.ExprLexer
- getSerializedATN() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- getSerializedSize() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectBufferStore.TransferredBuffer
- getSerializedSize() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnHeader
- getSerializedSize() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnSerializer
- 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.CompressedBlockSerializer
- 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.CompressedLongsSerializer
- getSerializedSize() - Method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSerializer
- 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.EncodedStringDictionaryWriter
- 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.FixedIndexedIntWriter
- getSerializedSize() - Method in class org.apache.druid.segment.data.FixedIndexedWriter
- getSerializedSize() - Method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
- getSerializedSize() - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- 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() - 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.nested.FieldTypeInfo.Writer
- getSerializedSize() - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- getSerializedSize() - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- getSerializedSize() - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- getSerializedSize() - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- getSerializedSize() - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadSerializer
- getSerializedSize() - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter
- getSerializedSize() - Method in class org.apache.druid.segment.serde.cell.CellIndexWriter
- getSerializedSize() - Method in class org.apache.druid.segment.serde.cell.CellWriter
- getSerializedSize() - Method in class org.apache.druid.segment.serde.cell.IndexWriter
- getSerializedSize() - Method in class org.apache.druid.segment.serde.cell.IntSerializer
- getSerializedSize() - Method in class org.apache.druid.segment.serde.cell.LongSerializer
- getSerializedSize() - Method in interface org.apache.druid.segment.serde.cell.NumberSerializer
- getSerializedSize() - Method in interface org.apache.druid.segment.serde.cell.StorableBuffer
- 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. - getSerializedSize(int, int) - Static method in class org.apache.druid.segment.data.VSizeLongSerde
- getSerializedStringByteSize(String) - Method in class org.apache.druid.common.utils.SerializerUtils
- getSerializer() - Method in interface org.apache.druid.segment.serde.ColumnPartSerde
- getSerializer() - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde
- 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
- getSerializer() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- getSerializer() - Method in class org.apache.druid.segment.serde.NullColumnPartSerde
- 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(SerializerProvider, Class<?>) - Static method in class org.apache.druid.java.util.common.jackson.JacksonUtils
-
Returns a serializer for a particular class.
- getSerializer(SegmentWriteOutMedium, String) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
- getSerializer(SegmentWriteOutMedium, String) - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexMetricSerde
- getSerializer(SegmentWriteOutMedium, String) - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexMetricSerde
- getSerializer(SegmentWriteOutMedium, String) - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexMetricSerde
- getSerializer(SegmentWriteOutMedium, String) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexMetricSerde
- 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.
- getService() - Method in class org.apache.druid.audit.RequestInfo
- getService() - Method in class org.apache.druid.java.util.emitter.service.AlertEvent
- getService() - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- getSeverity() - Method in class org.apache.druid.java.util.emitter.service.AlertEvent
- getShardSpec() - Method in class org.apache.druid.timeline.DataSegment
- getShardSpec(long, InputRow) - Method in interface org.apache.druid.timeline.partition.ShardSpecLookup
-
Returns a
ShardSpec
for the given timestamp and the inputRow. - getShardSpecClass() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- getShardSpecClass() - Method in class org.apache.druid.timeline.partition.LinearPartialShardSpec
- getShardSpecClass() - Method in class org.apache.druid.timeline.partition.NumberedOverwritePartialShardSpec
- getShardSpecClass() - Method in class org.apache.druid.timeline.partition.NumberedPartialShardSpec
- getShardSpecClass() - Method in interface org.apache.druid.timeline.partition.PartialShardSpec
-
Returns the class of the shardSpec created by this factory.
- getShardSpecClass() - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- getShares() - Method in class org.apache.druid.java.util.metrics.cgroups.Cpu.CpuAllocationMetric
- getShort() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getShort(long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- getShortArray(long, short[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- getShortArray(short[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getShouldAggregateNullInputs() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getShouldCombineAggregateNullInputs() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- getSigar() - Static method in class org.apache.druid.java.util.metrics.SigarUtil
- getSimpleAggregatorCacheKeySupplier(byte, String, Supplier<Expr>) - Static method in class org.apache.druid.query.aggregation.AggregatorUtil
- getSimpleType() - Method in class org.apache.druid.segment.nested.NestedDataColumnSupplierV4
- getSingleInputName() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
If and only if the expression has a single input, get the name of that input
- getSingleInputType() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
If and only if the column has a single input, get the
ValueType
of that input - getSingleType() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- getSingleType() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.TypeSet
-
If the set contains only a single
ColumnType
, return it, else null - getSingleValueRow(int) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
- getSingleValueRow(int) - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- getSingleValueRow(int) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- getSingleValueRow(int) - Method in class org.apache.druid.segment.nested.VariantColumn
- getSize() - Method in class org.apache.druid.collections.spatial.RTree
- getSize() - Method in class org.apache.druid.data.input.impl.CloudObjectSplitWidget.LocationWithSize
- getSize() - Method in class org.apache.druid.data.input.InputFileAttribute
- getSize() - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue.ObjectContainer
- 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
- getSize() - Method in class org.apache.druid.segment.data.CompressedBlockReader
-
Get size in bytes of virtual contiguous buffer
- getSize() - Method in class org.apache.druid.segment.loading.LoadSpec.LoadSpecResult
- getSize() - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessedValue
- getSize() - Method in class org.apache.druid.segment.serde.cell.IntIndexView.EntrySpan
- getSize() - Method in class org.apache.druid.segment.serde.cell.PayloadEntrySpan
- getSize() - Method in class org.apache.druid.timeline.DataSegment
- 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
- getSkipHeaderRows() - Method in class org.apache.druid.data.input.impl.CSVParseSpec
- getSkipHeaderRows() - Method in class org.apache.druid.data.input.impl.DelimitedParseSpec
- getSkipHeaderRows() - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- getSkipValueRangeIndexScale() - Method in class org.apache.druid.query.DruidProcessingIndexesConfig
- getSlf4jLogger() - Method in class org.apache.druid.java.util.common.logger.Logger
- getSlice(ByteBuffer, int, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.Groupers
- getSlowestPartitionInitializedTime() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
- getSmileMapper(Injector) - Method in class org.apache.druid.guice.DruidSecondaryModule
- getSnapshotColumnCapabilities(String) - Method in class org.apache.druid.segment.incremental.IncrementalIndexStorageAdapter
-
Sad workaround for
SegmentAnalyzer
to deal with the fact that the response fromIncrementalIndexStorageAdapter.getColumnCapabilities(java.lang.String)
is not accurate for string columns, in that it reports all 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
- getSortColumns() - Method in class org.apache.druid.query.operator.NaiveSortOperatorFactory
- getSortedArrays() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- getSortedCollector() - Method in class org.apache.druid.segment.nested.ValueDictionary
- getSortedDoubles() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- getSortedEncodedValueFromUnsorted(Integer) - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- getSortedIdFromUnsortedId(int) - Method in class org.apache.druid.segment.ComparatorSortedDimensionDictionary
- getSortedIdFromUnsortedId(int) - Method in class org.apache.druid.segment.SortedDimensionDictionary
- getSortedIndexedValues() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getSortedIndexedValues() - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- 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.NestedDataColumnIndexerV4
- getSortedLongs() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- getSortedStrings() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- getSortedValueLookups() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getSortedValueLookups() - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- getSortedValues() - Method in class org.apache.druid.query.filter.TypedInFilter
- getSource() - Method in exception org.apache.druid.frame.write.InvalidFieldException
- getSource() - Method in exception org.apache.druid.frame.write.InvalidNullByteException
- getSpatialDimensions() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
-
Deprecated.
- 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.
- getSplitHintSpecOrDefault(SplitHintSpec) - Method in interface org.apache.druid.data.input.impl.SplittableInputSource
- getSplitWidget() - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
-
Returns
CloudObjectSplitWidget
, which is used to implementCloudObjectInputSource.createSplits(InputFormat, SplitHintSpec)
. - getSqlQueryId() - Method in interface org.apache.druid.query.Query
- getSslContext() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- getSslHandshakeTimeout() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- getStandardDeviation() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- getStart() - Method in class org.apache.druid.frame.key.ClusterByPartition
-
Get the starting key for this range.
- getStart() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- getStart() - Method in class org.apache.druid.segment.serde.cell.IntIndexView.EntrySpan
- getStart() - Method in class org.apache.druid.segment.serde.cell.PayloadEntrySpan
- getStart() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- getStart() - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- getStart() - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- getStart() - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- getStart() - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- getStart() - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- 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
- getStartRootPartitionId() - Method in class org.apache.druid.timeline.DataSegment
- getStartRootPartitionId() - Method in interface org.apache.druid.timeline.Overshadowable
-
All overshadowables have root partition range.
- getStartRootPartitionId() - Method in class org.apache.druid.timeline.partition.NumberedOverwritePartialShardSpec
- getStartRootPartitionId() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- getStartRootPartitionId() - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
Returns the start root partition ID of the atomic update group which this segment belongs to.
- getStartRow() - Method in class org.apache.druid.query.rowsandcols.util.FindResult
- getStartTuple() - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- getStartTuple() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- getState() - Method in class org.apache.druid.common.config.Log4jShutdown
- getStats() - Method in interface org.apache.druid.indexer.Jobby
- getStatus() - Method in class org.apache.druid.indexer.TaskInfo
- getStatus() - Method in class org.apache.druid.indexer.TaskStatusPlus
-
Deprecated.
- getStatus() - Method in class org.apache.druid.java.util.http.client.response.FullResponseHolder
- getStatus() - Method in class org.apache.druid.java.util.http.client.response.StatusResponseHolder
- getStatus() - Method in interface org.apache.druid.timeline.LogicalSegment
- getStatus() - Method in class org.apache.druid.timeline.TimelineObjectHolder
- getStatus(String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Retrieve the status for the entry with the given id.
- getStatusCode() - Method in exception org.apache.druid.error.DruidException
- getStatusCode() - Method in class org.apache.druid.indexer.TaskStatus
- getStatusCode() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getStatusType() - Method in interface org.apache.druid.metadata.MetadataStorageActionHandlerTypes
- getStorageBuffer() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getStorageDir(DataSegment) - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
-
Deprecated.backward-compatibiliy shim that should be removed on next major release; use
DataSegmentPusher.getStorageDir(DataSegment, boolean)
instead. - getStorageDir(DataSegment, boolean) - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
- getStrategy() - Method in class org.apache.druid.segment.column.BaseTypeSignature
- getStrategy() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
- getStrategy() - Method in interface org.apache.druid.segment.column.TypeSignature
-
A
TypeStrategy
provides facilities to reading and writing values to buffers, as well as basic value comparators and byte size estimation. - getString(String) - Method in class org.apache.druid.query.QueryContext
-
Return a value as an
String
, returning {@link null} if the context value is not set. - getString(String, String) - Method in class org.apache.druid.query.QueryContext
- getString(Map<String, Object>, String) - Static method in class org.apache.druid.java.util.common.MapUtils
- getString(Map<String, Object>, String, String) - Static method in class org.apache.druid.java.util.common.MapUtils
- getStringBufferMapper() - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- getStringCardinality() - Method in class org.apache.druid.segment.nested.SortedValueDictionary
- getStringDictionary() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- getStringDictionary() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getStringDictionary() - Method in interface org.apache.druid.segment.nested.NestedCommonFormatColumn
- getStringDictionary() - Method in class org.apache.druid.segment.nested.VariantColumn
- getStringDictionaryEncoding() - Method in class org.apache.druid.segment.IndexSpec
- getStringDictionarySupplier(SmooshedFileMapper, ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.column.StringEncodingStrategies
- getStringDictionaryWriter(StringEncodingStrategy, SegmentWriteOutMedium, String) - Static method in class org.apache.druid.segment.column.StringEncodingStrategies
- 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
-
Subtotals spec may be empty which has a distinct meaning from
null
. - getSuccessfulSendingTimeCounter() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getSuffix() - Method in enum org.apache.druid.utils.CompressionUtils.Format
- getSuffixMatch() - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
- getSupervisorTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getSupportLowerBound() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
- getSupportUpperBound() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
- getSystemFieldValue(InputEntity, SystemField) - Method in class org.apache.druid.data.input.impl.HttpInputSource
- getSystemFieldValue(InputEntity, SystemField) - Method in class org.apache.druid.data.input.impl.LocalInputSource
- getSystemFieldValue(InputEntity, SystemField) - Method in interface org.apache.druid.data.input.impl.systemfield.SystemFieldInputSource
-
Compute the value of a system field for a particular
InputEntity
. - getTable(long[], int, int[], int, int, int, long[]) - Method in interface org.apache.druid.segment.data.VSizeLongSerde.LongDeserializer
-
Unpack a contiguous vector of long values at the specified indexes and lookup and replace stored values based on their index in the supplied value lookup 'table'
- getTable(long[], int, int, int, long[]) - Method in interface org.apache.druid.segment.data.VSizeLongSerde.LongDeserializer
-
Unpack a contiguous vector of long values at the specified start index of length and lookup and replace stored values based on their index in the supplied value lookup 'table'
- getTableBuffer() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- getTableName() - Method in class org.apache.druid.metadata.MetadataCASUpdate
- 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.FilteredDataSource
- getTableNames() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- 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
-
Asserts that the children of the union are all table data sources before returning the table names
- getTableNames() - Method in class org.apache.druid.query.UnnestDataSource
- getTableStart() - Method in class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
- getTargetPersona() - Method in exception org.apache.druid.error.DruidException
- getTargetRowsPerSegment() - Method in interface org.apache.druid.indexer.partitions.DimensionBasedPartitionsSpec
- getTargetRowsPerSegment() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- getTargetRowsPerSegment() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- getTask() - Method in class org.apache.druid.indexer.TaskInfo
- getTaskCount() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
-
Total number of
ForkJoinPool
tasks involved in executing theParallelMergeCombiningSequence
, includingParallelMergeCombiningSequence.MergeCombinePartitioningAction
,ParallelMergeCombiningSequence.PrepareMergeCombineInputsAction
, andParallelMergeCombiningSequence.MergeCombineAction
. - getTaskEntryType() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getTaskId() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrorsTaskReport
- getTaskId() - Method in class org.apache.druid.indexer.report.KillTaskReport
- getTaskId() - Method in class org.apache.druid.indexer.report.TaskContextReport
- getTaskId() - Method in interface org.apache.druid.indexer.report.TaskReport
- getTaskIdOutputsFolderName(String, int, int, String) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
-
Fetches the directory location where a particular worker will store the partition files corresponding to the stage number, and it's task id
- getTaskInfo(String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
- getTaskInfos(Map<TaskLookup.TaskLookupType, TaskLookup>, String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Returns a list of
TaskInfo
from metadata store that matches to the given filters. - getTaskInfos(TaskLookup, String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
- getTaskLockTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getTaskLogTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getTasksCreatedPriorTo() - Method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- getTasksTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getTaskStatusList(Map<TaskLookup.TaskLookupType, TaskLookup>, String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Returns the statuses of the specified tasks.
- getTempDir() - Static method in class org.apache.druid.java.util.common.FileUtils
- getTempDirSupplier() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- getThreadPriorityFromTaskPriority(int) - Static method in class org.apache.druid.concurrent.TaskThreadPriority
-
Return the thread-factory friendly priorities from the task priority
- 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
- getThrownAway() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- getTime() - Method in class org.apache.druid.frame.segment.FrameCursor
- 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
- getTime() - Method in class org.apache.druid.segment.UnnestColumnValueSelectorCursor
- getTime() - Method in class org.apache.druid.segment.UnnestDimensionCursor
- getTimeColumn() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- getTimeColumn() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- getTimeColumn() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- getTimeColumn() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- getTimeColumn() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- getTimeColumn() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- getTimeColumn() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- getTimeColumn() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- getTimeFormat() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
- getTimeOfExceptionMillis() - Method in exception org.apache.druid.java.util.common.parsers.ParseException
- getTimeOfExceptionMillis() - Method in class org.apache.druid.segment.incremental.ParseExceptionReport
- getTimeOrder() - Method in class org.apache.druid.query.scan.ScanQuery
-
If this query is purely-time-ordered, returns a value of the enum
ScanQuery.Order
. - getTimeout() - Method in class org.apache.druid.query.QueryContext
- getTimeout(long) - Method in class org.apache.druid.query.QueryContext
- getTimeoutTime() - Method in class org.apache.druid.query.context.ResponseContext
- getTimeRange() - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- getTimestamp() - Method in class org.apache.druid.data.input.ListBasedInputRow
- getTimestamp() - Method in class org.apache.druid.data.input.MapBasedRow
- getTimestamp() - Method in interface org.apache.druid.data.input.Row
-
Returns the timestamp from the epoch as an org.joda.time.DateTime.
- 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.TransformedInputRow
- getTimestampColumn() - Method in class org.apache.druid.data.input.impl.TimestampSpec
- getTimestampFormat() - Method in class org.apache.druid.data.input.impl.TimestampSpec
- getTimestampFromEpoch() - Method in class org.apache.druid.data.input.ListBasedInputRow
- getTimestampFromEpoch() - Method in class org.apache.druid.data.input.MapBasedRow
- getTimestampFromEpoch() - Method in interface org.apache.druid.data.input.Row
-
Returns the timestamp from the epoch in milliseconds.
- getTimestampFromEpoch() - Method in class org.apache.druid.segment.transform.TransformedInputRow
- getTimestampResultField() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
- getTimestampSpec() - Method in class org.apache.druid.data.input.impl.ParseSpec
-
Deprecated.
- getTimestampSpec() - Method in class org.apache.druid.data.input.InputRowSchema
- 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
- getTimeSumAndCountAndReset() - Method in class org.apache.druid.java.util.emitter.core.ConcurrentTimeCounter
- getTimezone() - Method in class org.apache.druid.query.BaseQuery
- getTimezone() - Method in interface org.apache.druid.query.Query
- getTimezone() - Method in class org.apache.druid.query.select.SelectQuery
-
Deprecated.
- getTimeZone() - Method in class org.apache.druid.java.util.common.granularity.Granularity
- getTimeZone() - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- getTimeZone() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
- getTlsPort() - Method in class org.apache.druid.indexer.TaskLocation
- 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
- getToIndex(long) - Method in class org.apache.druid.query.operator.OffsetLimit
-
Returns the last row index to fetch (non-inclusive).
- getTokenNames() - Method in class org.apache.druid.math.expr.antlr.ExprLexer
-
Deprecated.
- getTokenNames() - Method in class org.apache.druid.math.expr.antlr.ExprParser
-
Deprecated.
- 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() - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryRunnerFactory
- getToolchest() - Method in class org.apache.druid.query.operator.WindowOperatorQueryQueryRunnerFactory
- getToolchest() - Method in interface org.apache.druid.query.QueryRunnerFactory
-
Provides access to the
QueryToolChest
for this specificQuery
type. - 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
- getToolChest(QueryType) - Method in class org.apache.druid.query.MapQueryToolChestWarehouse
- getToolChest(QueryType) - Method in interface org.apache.druid.query.QueryToolChestWarehouse
- getToolChest(QueryType) - Method in class org.apache.druid.query.ReflectionQueryToolChestWarehouse
-
Deprecated.
- getToolchestMergeBuffer() - Method in class org.apache.druid.query.groupby.GroupByQueryResources
-
Returns a merge buffer associate with the
GroupByQueryQueryToolChest.mergeResults(org.apache.druid.query.QueryRunner<org.apache.druid.query.groupby.ResultRow>)
- 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
- getTotalAllocatedBuffers() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
-
This and the following methods are public for external monitoring purposes.
- getTotalBytes() - Method in class org.apache.druid.query.context.ResponseContext
- getTotalCpuTime() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
-
Total CPU time in nanoseconds during the 'hot loop' of doing actual merging and combining in
ParallelMergeCombiningSequence.MergeCombineAction
- getTotalDroppedBuffers() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getTotalEmittedEvents() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getTotalFailedBuffers() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- getTotalHeapSizeBytes() - Method in class org.apache.druid.utils.RuntimeInfo
- getTotalMergersForUltimateLevel() - Method in class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- getTotalMergingLevels() - Method in class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- getTotalMetrics() - Method in interface org.apache.druid.indexer.TaskMetricsGetter
- getTotals() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
- getTotals() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
- getTotals() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- getTotalSize() - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriter
- getTotalSize() - Method in interface org.apache.druid.frame.write.FrameWriter
-
Returns the number of bytes that would be written by
FrameWriter.writeTo(org.apache.datasketches.memory.WritableMemory, long)
if called now. - getTotalSize() - Method in class org.apache.druid.frame.write.RowBasedFrameWriter
- getTotalTime() - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence.MergeCombineMetrics
- getTransforms() - Method in class org.apache.druid.segment.transform.TransformSpec
- getTransformSpec() - Method in class org.apache.druid.timeline.CompactionState
- getTrueInterval() - Method in interface org.apache.druid.timeline.LogicalSegment
- getTrueInterval() - Method in class org.apache.druid.timeline.TimelineObjectHolder
- getType() - Method in class org.apache.druid.audit.AuditEntry
- getType() - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader.NumericArrayFrameColumn
- getType() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- getType() - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- getType() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- getType() - Method in interface org.apache.druid.indexer.partitions.PartitionsSpec
- getType() - Method in class org.apache.druid.indexer.TaskIdentifier
- getType() - Method in class org.apache.druid.indexer.TaskStatusPlus
- getType() - Method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- getType() - Method in class org.apache.druid.math.expr.InputBindings.InputSupplier
- getType() - Method in class org.apache.druid.math.expr.vector.ExprEvalDoubleVector
- getType() - Method in class org.apache.druid.math.expr.vector.ExprEvalLongVector
- getType() - Method in class org.apache.druid.math.expr.vector.ExprEvalObjectVector
- getType() - Method in class org.apache.druid.math.expr.vector.ExprEvalVector
- getType() - Method in class org.apache.druid.metadata.TaskLookup.ActiveTaskLookup
- getType() - Method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- getType() - Method in interface org.apache.druid.metadata.TaskLookup
- getType() - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Deprecated.
- getType() - Method in interface org.apache.druid.query.aggregation.PostAggregator
-
Deprecated.
- 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
-
Deprecated.
- getType() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- getType() - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- getType() - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- getType() - Method in interface org.apache.druid.query.Query
- getType() - Method in class org.apache.druid.query.rowsandcols.column.accessor.DoubleColumnAccessorBase
- getType() - Method in class org.apache.druid.query.rowsandcols.column.accessor.FloatColumnAccessorBase
- getType() - Method in class org.apache.druid.query.rowsandcols.column.accessor.LongColumnAccessorBase
- getType() - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Get the type of the Column
- getType() - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- 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 class org.apache.druid.segment.column.BaseTypeSignature
- getType() - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- getType() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- getType() - Method in interface org.apache.druid.segment.column.StringEncodingStrategy
- getType() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.Utf8
- getType() - Method in interface org.apache.druid.segment.column.TypeSignature
-
TypeDescriptor
enumeration used to handle different classes of types - 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
- getType() - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- getType() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- getType() - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
Get the type name of this ShardSpec.
- getType() - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- getType() - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- getType(String) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldLambdaBinding
- getType(String) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianMapLambdaBinding
- getType(String) - Method in class org.apache.druid.math.expr.ApplyFunction.FoldLambdaBinding
- getType(String) - Method in class org.apache.druid.math.expr.ApplyFunction.LambdaInputBindingInspector
- getType(String) - Method in class org.apache.druid.math.expr.ApplyFunction.MapLambdaBinding
- getType(String) - Method in class org.apache.druid.math.expr.ApplyFunction.SettableLambdaBinding
- getType(String) - Method in interface org.apache.druid.math.expr.Expr.InputBindingInspector
-
Get the
ExpressionType
from the backing store for a given identifier (this is likely a column, but could be other things depending on the backing adapter) - getType(String) - Method in class org.apache.druid.math.expr.InputBindings.BestEffortInputBindings
- getType(String) - Method in class org.apache.druid.math.expr.SettableObjectBinding
- getType(String) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorInputBindings
- getType(String) - Method in interface org.apache.druid.segment.ColumnInspector
- getType(String) - Method in class org.apache.druid.segment.virtual.ExpressionVectorInputBinding
- getType(String) - Method in class org.apache.druid.segment.virtual.SingleInputBindings
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniqueFinalizingPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.ArithmeticPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.ConstantPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.DoubleGreatestPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.DoubleLeastPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.ExpressionPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.FieldAccessPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.FinalizingFieldAccessPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.JavaScriptPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
- getType(ColumnInspector) - Method in class org.apache.druid.query.aggregation.post.LongLeastPostAggregator
- getType(ColumnInspector) - Method in interface org.apache.druid.query.aggregation.PostAggregator
-
Return the output type of a row processed with this post aggregator.
- getTypeByteOrder() - Method in class org.apache.druid.segment.data.SafeWritableBase
- getTypeName() - Method in class org.apache.druid.data.input.impl.DimensionSchema
- getTypeName() - Method in class org.apache.druid.data.input.impl.DoubleDimensionSchema
- getTypeName() - Method in class org.apache.druid.data.input.impl.FloatDimensionSchema
- getTypeName() - Method in class org.apache.druid.data.input.impl.LongDimensionSchema
- getTypeName() - Method in class org.apache.druid.data.input.impl.NewSpatialDimensionSchema
- getTypeName() - Method in class org.apache.druid.data.input.impl.StringDimensionSchema
- getTypeName() - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
- getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexColumn
- getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexMetricSerde
- getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn
- getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexMetricSerde
- getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn
- getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexMetricSerde
- getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn
- getTypeName() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexMetricSerde
- getTypeName() - Method in class org.apache.druid.segment.AutoTypeColumnSchema
- 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.nested.NestedDataComplexColumn
- getTypeName() - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- getTypeName() - Method in class org.apache.druid.segment.NestedDataColumnSchema
- getTypeName() - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde
- getTypeName() - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
- getTypes() - Method in class org.apache.druid.data.input.impl.CombiningInputSource
- getTypes() - Method in class org.apache.druid.data.input.impl.HttpInputSource
- getTypes() - Method in class org.apache.druid.data.input.impl.InlineInputSource
- getTypes() - Method in class org.apache.druid.data.input.impl.LocalInputSource
- getTypes() - Method in interface org.apache.druid.data.input.InputSource
-
The types of input sources uses.
- getTypes(int) - Method in class org.apache.druid.segment.nested.FieldTypeInfo
- getTypeSignature() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- getTypeStrategy() - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- getTypeStrategy() - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
-
Get a
TypeStrategy
to assist with writing individual complex values to aByteBuffer
. - getTypeStrategy(ExpressionType) - Method in class org.apache.druid.math.expr.ExpressionTypeFactory
- getTypeStrategy(ColumnType) - Method in class org.apache.druid.segment.column.ColumnTypeFactory
- getTypeStrategy(Type) - Method in interface org.apache.druid.segment.column.TypeFactory
- getUnchecked(ListenableFuture<T>, boolean) - Static method in class org.apache.druid.common.guava.FutureUtils
-
Waits for a given future and returns its value, like
future.get()
. - getUncheckedImmediately(ListenableFuture<T>) - Static method in class org.apache.druid.common.guava.FutureUtils
-
Gets the result of a given future immediately.
- getUncoveredIntervals() - Method in class org.apache.druid.query.context.ResponseContext
- getUncoveredIntervalsLimit() - Method in class org.apache.druid.query.QueryContext
- getUncoveredIntervalsLimit(int) - Method in class org.apache.druid.query.QueryContext
- getUnderlyingException() - Method in class org.apache.druid.error.ErrorResponse
- getUnitSystem() - Method in class org.apache.druid.math.expr.Function.HumanReadableBinaryByteFormatFunc
- getUnitSystem() - Method in class org.apache.druid.math.expr.Function.HumanReadableDecimalByteFormatFunc
- getUnitSystem() - Method in class org.apache.druid.math.expr.Function.HumanReadableDecimalFormatFunc
- getUnitSystem() - Method in class org.apache.druid.math.expr.Function.SizeFormatFunc
- 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
-
Get set of inputs which were completely missing information, possibly a non-existent column or from a column selector factory with incomplete information
- getUnknownsBitmap() - Method in class org.apache.druid.segment.index.semantic.ValueSetIndexes.BaseValueSetIndexesFromIterable
- getUnknownsBitmap() - Method in class org.apache.druid.segment.index.SimpleImmutableBitmapDelegatingIterableIndex
- getUnnestColumn() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getUnnestFilter() - Method in class org.apache.druid.query.UnnestDataSource
- getUnnestFilter() - Method in class org.apache.druid.segment.UnnestStorageAdapter
- getUnnestInputIfDirectAccess(VirtualColumn) - Method in class org.apache.druid.segment.UnnestStorageAdapter
-
Returns the input of
UnnestStorageAdapter.unnestColumn
, if it's a direct access; otherwise returns null. - 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
- getUnparseable() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- getUnparseableEvents() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- 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
- getUnshared(int) - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- getUnsortedEncodedKeyComponentHashCode(int[]) - Method in class org.apache.druid.segment.StringDimensionIndexer
- 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(StructuredData) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getUnsortedEncodedKeyComponentHashCode(StructuredData) - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- 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(Integer) - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- getUnsortedEncodedValueFromSorted(Long) - Method in class org.apache.druid.segment.LongDimensionIndexer
- getUnsortedEncodedValueFromSorted(StructuredData) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- getUnsortedEncodedValueFromSorted(StructuredData) - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- getUnsortedIdFromSortedId(int) - Method in class org.apache.druid.segment.ComparatorSortedDimensionDictionary
- getUnsortedIdFromSortedId(int) - Method in class org.apache.druid.segment.SortedDimensionDictionary
- getUnusedConnectionTimeoutDuration() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- getUnusedConnectionTimeoutMillis() - Method in class org.apache.druid.java.util.http.client.pool.ResourcePoolConfig
- getUpgradeSegmentsTable() - Method in class org.apache.druid.metadata.MetadataStorageTablesConfig
- getUpper() - Method in class org.apache.druid.query.filter.BoundDimFilter
- getUpper() - Method in class org.apache.druid.query.filter.RangeFilter
- getUpperOffset() - Method in class org.apache.druid.query.operator.window.WindowFrame
- getUpperOffsetClamped(int) - Method in class org.apache.druid.query.operator.window.WindowFrame
-
Calculates the applicable upper offset if the max number of rows is known.
- getUri() - Method in class org.apache.druid.audit.RequestInfo
- getUri() - Method in class org.apache.druid.data.input.BytesCountingInputEntity
- getUri() - Method in class org.apache.druid.data.input.impl.ByteEntity
- getUri() - Method in class org.apache.druid.data.input.impl.FileEntity
- getUri() - Method in class org.apache.druid.data.input.impl.HttpEntity
- getUri() - Method in interface org.apache.druid.data.input.InputEntity
-
Returns an URI to identify the input entity.
- getUris() - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- getUris() - Method in class org.apache.druid.data.input.impl.HttpInputSource
- getUrl() - Method in class org.apache.druid.java.util.http.client.Request
- getURLsForClasspath(String) - Static method in class org.apache.druid.guice.ExtensionsLoader
- getUseBitmapIndex() - Method in class org.apache.druid.query.filter.FilterTuning
- getUser() - Method in class org.apache.druid.java.util.http.client.HttpClientProxyConfig
- getUser() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- getUserDims() - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- getUtf8ByteBuffersFromSelector(T) - Method in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
-
Extracts a list of ByteBuffers from the selector.
- getUtf8ByteBuffersFromStringArraySelector(BaseObjectColumnValueSelector) - Static method in class org.apache.druid.frame.write.FrameWriterUtils
-
Retrieves UTF-8 byte buffers from a
ColumnValueSelector
, which is expected to be the kind of selector you get for anARRAY<STRING>
column. - getUtf8ByteBuffersFromStringSelector(DimensionSelector, boolean) - Static method in class org.apache.druid.frame.write.FrameWriterUtils
-
Retrieves UTF-8 byte buffers from a
DimensionSelector
, which is expected to be the kind of selector you get for anSTRING
column. - getUtf8BytesDictionary() - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- getVal(int) - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader.NumericArrayFrameColumn
- getVal(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- getValue() - Method in class org.apache.druid.frame.util.SettableLongVirtualColumn
- getValue() - Method in exception org.apache.druid.frame.write.InvalidNullByteException
- getValue() - Method in class org.apache.druid.indexer.Property
- getValue() - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- getValue() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- getValue() - Method in class org.apache.druid.query.filter.ExtractionDimFilter
-
Deprecated.
- getValue() - Method in class org.apache.druid.query.filter.SelectorDimFilter
-
Value to filter against.
- 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() - 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
- getValue() - Method in class org.apache.druid.segment.nested.StructuredData
- getValue() - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessedValue
- getValue() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.FieldDimensionSelector
- getValue(int) - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
- getValue(int) - Method in class org.apache.druid.segment.DimensionDictionary
- getValue(int) - Method in class org.apache.druid.segment.index.IndexedStringDictionaryEncodedStringValueIndex
- getValue(int) - Method in interface org.apache.druid.segment.index.semantic.DictionaryEncodedValueIndex
-
Get the value in the underlying value dictionary of the specified dictionary id
- getValueCardinality() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
- getValueCardinality() - Method in class org.apache.druid.segment.ConstantDimensionSelector
- getValueCardinality() - Method in class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- 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.IdMapping
-
Get the number of values stored in
IdMapping.forwardMapping
- 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.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- getValueCardinality() - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector
- getValueColumn() - Method in class org.apache.druid.metadata.MetadataCASUpdate
- getValueDictionary() - Method in class org.apache.druid.segment.IndexableAdapter.NestedColumnMergable
- getValueForRewrite() - Method in class org.apache.druid.segment.join.filter.rewrite.RhsRewriteCandidate
- getValueFromBucket(ByteBuffer, int) - Static method in class org.apache.druid.segment.data.FrontCodedIndexed.FrontCodedV0
- getValueFromSortedId(int) - Method in class org.apache.druid.segment.ComparatorSortedDimensionDictionary
- getValueFromSortedId(int) - Method in class org.apache.druid.segment.SortedDimensionDictionary
- getValues() - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
- getValues() - Method in class org.apache.druid.query.filter.InDimFilter
- getValues() - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.Entry
- getValues() - Method in class org.apache.druid.query.groupby.epinephelinae.ReusableEntry
-
Returns the values array, which enables setting individual values.
- getValues() - Method in class org.apache.druid.query.search.FragmentSearchQuerySpec
- getValues() - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- getValues(int[]) - Method in class org.apache.druid.segment.DimensionDictionary
- getValueType() - Method in class org.apache.druid.frame.field.DoubleFieldReader
- getValueType() - Method in class org.apache.druid.frame.field.FloatFieldReader
- getValueType() - Method in class org.apache.druid.frame.field.LongFieldReader
- getValueType() - Method in class org.apache.druid.frame.field.NumericFieldReader
-
ValueType
of the inheritor's element - getValueType() - Method in class org.apache.druid.segment.column.ColumnDescriptor
- getValueTypesFromDimensionSpecs(List<DimensionSpec>) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- getVariable() - Method in class org.apache.druid.metadata.EnvironmentVariablePasswordProvider
- getVariables() - Method in class org.apache.druid.metadata.EnvironmentVariableDynamicConfigProvider
- getVariantTypeSetByte() - Method in class org.apache.druid.segment.nested.VariantColumnAndIndexSupplier
- getVectorize() - Method in class org.apache.druid.query.QueryContext
- getVectorize(QueryContexts.Vectorize) - Method in class org.apache.druid.query.QueryContext
- getVectorizeVirtualColumns() - Method in class org.apache.druid.query.QueryContext
- getVectorizeVirtualColumns(QueryContexts.Vectorize) - Method in class org.apache.druid.query.QueryContext
- getVectorSize() - Method in class org.apache.druid.query.QueryContext
- getVectorSize(int) - Method in class org.apache.druid.query.QueryContext
- getVersion() - Method in class org.apache.druid.hll.HyperLogLogCollector
- getVersion() - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- getVersion() - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- getVersion() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnHeader
- getVersion() - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
- getVersion() - Method in class org.apache.druid.query.SegmentDescriptor
- getVersion() - Method in class org.apache.druid.segment.ReferenceCountingSegment
- getVersion() - Method in class org.apache.druid.timeline.DataSegment
- getVersion() - Method in interface org.apache.druid.timeline.Overshadowable
- getVersion() - Method in class org.apache.druid.timeline.SegmentId
- getVersion() - Method in class org.apache.druid.timeline.TimelineObjectHolder
- getVersion() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline.PartitionChunkEntry
- getVersion() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline.TimelineEntry
- getVersion(URI) - Method in interface org.apache.druid.segment.loading.URIDataPuller
-
Returns an abstract "version" for the URI.
- getVersionFromDir(File) - Static method in class org.apache.druid.segment.SegmentUtils
- getVirtualColumn() - Method in class org.apache.druid.query.UnnestDataSource
- getVirtualColumn(String) - Method in class org.apache.druid.segment.VirtualColumns
- getVirtualColumnCandidates() - Method in class org.apache.druid.query.JoinDataSource
-
Computes a set of column names for left table expressions in join condition which may already have been defined as a virtual column in the virtual column registry.
- getVirtualColumns() - Method in class org.apache.druid.query.groupby.GroupByQuery
- getVirtualColumns() - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- 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.search.SearchQuery
- 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
- getVocabulary() - Method in class org.apache.druid.math.expr.antlr.ExprLexer
- getVocabulary() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- getWeightedSize() - Method in class org.apache.druid.data.input.InputFileAttribute
- getWeightedSize(String, long) - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- getWeightedSize(String, long) - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- getWeightedSize(String, long) - Method in class org.apache.druid.data.input.impl.RegexInputFormat
- getWeightedSize(String, long) - Method in interface org.apache.druid.data.input.InputFormat
-
Computes the weighted size of a given input object of the underyling input format type, weighted for its cost during ingestion.
- getWords() - Method in class org.apache.druid.extendedset.intset.ConciseSet
- getWorkerOutputSuccessFilePath(String, int, int) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
- getWorkerPoolSize() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- getWritableChannel() - Method in class org.apache.druid.frame.processor.OutputChannel
-
Returns the writable channel of this pair.
- getWritableChannel() - Method in class org.apache.druid.frame.processor.PartitionedOutputChannel
-
Returns the writable channel of this pair.
- getZipfExponent() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- giveBack() - Method in class org.apache.druid.frame.processor.Bouncer.Ticket
- Global - Annotation Type in org.apache.druid.guice.annotations
- globalDictionary - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
- globalDictionary - Variable in class org.apache.druid.segment.NestedDataColumnIndexerV4
- GlobalDictionaryEncodedFieldColumnWriter<T> - Class in org.apache.druid.segment.nested
-
Base class for writer of global dictionary encoded nested field columns for
NestedDataColumnSerializer
. - GlobalDictionaryEncodedFieldColumnWriter(String, String, SegmentWriteOutMedium, IndexSpec, DictionaryIdLookup) - Constructor for class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- globalDictionaryIdLookup - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- GlobalTableDataSource - Class in org.apache.druid.query
-
TableDataSource
variant for globally available 'broadcast' segments. - GlobalTableDataSource(String) - Constructor for class org.apache.druid.query.GlobalTableDataSource
- go(Request, HttpResponseHandler<Intermediate, Final>) - Method in class org.apache.druid.java.util.http.client.AbstractHttpClient
- go(Request, HttpResponseHandler<Intermediate, Final>) - Method in interface org.apache.druid.java.util.http.client.HttpClient
-
Submit a request and process the response with the given response handler.
- go(Request, HttpResponseHandler<Intermediate, Final>, Duration) - Method in class org.apache.druid.java.util.http.client.CredentialedHttpClient
- go(Request, HttpResponseHandler<Intermediate, Final>, Duration) - Method in interface org.apache.druid.java.util.http.client.HttpClient
-
Submit a request and process the response with the given response handler.
- go(Request, HttpResponseHandler<Intermediate, Final>, Duration) - Method in class org.apache.druid.java.util.http.client.NettyHttpClient
- go(Operator, Operator.Receiver) - Static method in interface org.apache.druid.query.operator.Operator
-
Convenience method to run an Operator until completion.
- GO - org.apache.druid.query.operator.Operator.Signal
-
Indicates that more data is welcome.
- goOrContinue(Closeable, Operator.Receiver) - Method in class org.apache.druid.query.operator.join.SortedInnerJoinOperator
- goOrContinue(Closeable, Operator.Receiver) - Method in class org.apache.druid.query.operator.LimitTimeIntervalOperator
- goOrContinue(Closeable, Operator.Receiver) - Method in class org.apache.druid.query.operator.NaivePartitioningOperator
- goOrContinue(Closeable, Operator.Receiver) - Method in class org.apache.druid.query.operator.NaiveSortOperator
- goOrContinue(Closeable, Operator.Receiver) - Method in interface org.apache.druid.query.operator.Operator
-
This is the primary workhorse method of an Operator.
- goOrContinue(Closeable, Operator.Receiver) - Method in class org.apache.druid.query.operator.ScanOperator
- goOrContinue(Closeable, Operator.Receiver) - Method in class org.apache.druid.query.operator.SegmentToRowsAndColumnsOperator
- goOrContinue(Closeable, Operator.Receiver) - Method in class org.apache.druid.query.operator.SequenceOperator
- goOrContinue(Closeable, Operator.Receiver) - Method in class org.apache.druid.query.operator.WindowProcessorOperator
- Granularities - Class in org.apache.druid.java.util.common.granularity
-
This class was created b/c sometimes static initializers of a class that use a subclass can deadlock.
- Granularities() - Constructor for class org.apache.druid.java.util.common.granularity.Granularities
- granularitiesFinerThan(Granularity) - Static method in class org.apache.druid.java.util.common.granularity.Granularity
-
Returns a list of standard granularities that are equal to, or finer than, a provided granularity.
- granularity(String) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- granularity(Granularity) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- granularity(Granularity) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- granularity(Granularity) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- 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(TopNQuery) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
-
Sets the granularity of
BaseQuery.getGranularity()
of the given query as dimension. - Granularity - Class in org.apache.druid.java.util.common.granularity
- Granularity() - Constructor for class org.apache.druid.java.util.common.granularity.Granularity
- Granularity.Formatter - Enum in org.apache.druid.java.util.common.granularity
- granularityIntervalsIterator() - Method in class org.apache.druid.java.util.common.granularity.IntervalsByGranularity
- GranularityModule - Class in org.apache.druid.jackson
- GranularityModule() - Constructor for class org.apache.druid.jackson.GranularityModule
- GranularityModule.GranularityMixin - Interface in org.apache.druid.jackson
- GranularityType - Enum in org.apache.druid.java.util.common.granularity
-
Only to create a mapping of the granularity and all the supported file patterns namely: default, lowerDefault and hive.
- greaterThan(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorComparisonProcessors
- 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
- greaterThanOrEqual(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorComparisonProcessors
- GreatestFunc() - Constructor for class org.apache.druid.math.expr.Function.GreatestFunc
- GROUP_BY - Static variable in interface org.apache.druid.query.Query
- GROUP_BY_MISSING_VALUE - Static variable in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
-
Index to indicate the absence of a key in the dictionary
- GROUP_ID - Static variable in class org.apache.druid.query.DruidMetrics
- groupable() - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- groupable() - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- groupable() - Method in class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
- groupable() - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- groupable() - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- groupable() - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- groupable() - Method in class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- groupable() - Method in interface org.apache.druid.segment.column.TypeStrategy
-
Whether the type is groupable or not.
- 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.
- GroupByColumnSelectorStrategyFactory - Class in org.apache.druid.query.groupby.epinephelinae
-
Creates
ColumnSelectorStrategy
s for grouping dimensions If the type is STRING, then it delegates the group by handling toKeyMappingMultiValueGroupByColumnSelectorStrategy
which is specialized forDimensionSelector
s and multi-value dimensions. - GroupByColumnSelectorStrategyFactory() - Constructor for class org.apache.druid.query.groupby.epinephelinae.GroupByColumnSelectorStrategyFactory
- GroupByMergingQueryRunner - Class in org.apache.druid.query.groupby.epinephelinae
-
Class that knows how to merge a collection of groupBy
QueryRunner
objects, calledqueryables
, using a buffer provided bymergeBufferPool
and a parallel executor provided byexec
. - GroupByMergingQueryRunner(GroupByQueryConfig, DruidProcessingConfig, QueryProcessingPool, QueryWatcher, Iterable<QueryRunner<ResultRow>>, GroupByResourcesReservationPool, int, int, ObjectMapper, String) - Constructor for class org.apache.druid.query.groupby.epinephelinae.GroupByMergingQueryRunner
- 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.epinephelinae
-
Contains logic to process a groupBy query on a single
StorageAdapter
in a non-vectorized manner. - GroupByQueryMetrics - Interface in org.apache.druid.query.groupby
-
Specialization of
QueryMetrics
forGroupByQuery
. - 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
-
Toolchest for GroupBy queries
- GroupByQueryQueryToolChest(GroupingEngine, Supplier<GroupByQueryConfig>, GroupByQueryMetricsFactory, GroupByResourcesReservationPool) - Constructor for class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- GroupByQueryQueryToolChest(GroupingEngine, GroupByResourcesReservationPool) - Constructor for class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- GroupByQueryResources - Class in org.apache.druid.query.groupby
-
This class contains resources required for a groupBy query execution.
- GroupByQueryResources(List<ReferenceCountingResourceHolder<ByteBuffer>>, List<ReferenceCountingResourceHolder<ByteBuffer>>) - Constructor for class org.apache.druid.query.groupby.GroupByQueryResources
- GroupByQueryRunnerFactory - Class in org.apache.druid.query.groupby
- GroupByQueryRunnerFactory(GroupingEngine, GroupByQueryQueryToolChest) - Constructor for class org.apache.druid.query.groupby.GroupByQueryRunnerFactory
- GroupByResourcesReservationPool - Class in org.apache.druid.query.groupby
-
Reserves the
GroupByQueryResources
for a given group by query and maps them to the query's resource ID. - GroupByResourcesReservationPool(BlockingPool<ByteBuffer>, GroupByQueryConfig) - Constructor for class org.apache.druid.query.groupby.GroupByResourcesReservationPool
- GroupByResultMergeFn - 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. - GroupByResultMergeFn(GroupByQuery) - Constructor for class org.apache.druid.query.groupby.epinephelinae.GroupByResultMergeFn
- 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
- 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> - Interface 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
-
Set of utility methods to faciliate implementation of
Grouper.KeySerde.bufferComparator()
andGrouper.KeySerde.bufferComparatorWithAggregators(AggregatorFactory[], int[])
- GrouperBufferComparatorUtils() - Constructor for class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
- Groupers - Class in org.apache.druid.query.groupby.epinephelinae
- GROUPING_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- GroupingAggregatorFactory - Class in org.apache.druid.query.aggregation
-
This class implements
grouping
function to determine the grouping that a row is part of. - GroupingAggregatorFactory(String, List<String>) - Constructor for class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- GroupingEngine - Class in org.apache.druid.query.groupby
-
Common code for processing
GroupByQuery
. - GroupingEngine(DruidProcessingConfig, Supplier<GroupByQueryConfig>, NonBlockingPool<ByteBuffer>, GroupByResourcesReservationPool, ObjectMapper, ObjectMapper, QueryWatcher) - Constructor for class org.apache.druid.query.groupby.GroupingEngine
- GroupPartitioner - Interface in org.apache.druid.query.rowsandcols.semantic
-
A semantic interface used to partition a data set based on a given set of dimensions.
- groups() - Method in annotation type org.apache.druid.java.util.common.HumanReadableBytesRange
- groupSegmentsByInterval(Collection<DataSegment>) - Static method in class org.apache.druid.segment.SegmentUtils
- growthCount - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- GT - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- GT - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- GuavaUtils - Class in org.apache.druid.common.guava
- GuavaUtils() - Constructor for class org.apache.druid.common.guava.GuavaUtils
- guessAggregatorHeapFootprint(long) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Returns a best guess as to how much memory the on-heap
Aggregator
returned byAggregatorFactory.factorize(org.apache.druid.segment.ColumnSelectorFactory)
will require when a certain number of rows have been aggregated into it. - GuiceAnnotationIntrospector - Class in org.apache.druid.guice
- GuiceAnnotationIntrospector() - Constructor for class org.apache.druid.guice.GuiceAnnotationIntrospector
- GuiceExprMacroTable - Class in org.apache.druid.query.expression
- GuiceExprMacroTable(Set<ExprMacroTable.ExprMacro>) - Constructor for class org.apache.druid.query.expression.GuiceExprMacroTable
- GuiceInjectableValues - Class in org.apache.druid.guice
- GuiceInjectableValues(Injector) - Constructor for class org.apache.druid.guice.GuiceInjectableValues
- GuiceInjectors - Class in org.apache.druid.guice
-
Creates the startup injector.
- GuiceInjectors() - Constructor for class org.apache.druid.guice.GuiceInjectors
- gunzip(ByteSource, File) - Static method in class org.apache.druid.utils.CompressionUtils
-
Gunzip from the input stream to the output file
- gunzip(ByteSource, File, Predicate<Throwable>) - Static method in class org.apache.druid.utils.CompressionUtils
-
A gunzip function to store locally
- gunzip(File, File) - Static method in class org.apache.druid.utils.CompressionUtils
-
gunzip the file to the output file.
- gunzip(InputStream, File) - Static method in class org.apache.druid.utils.CompressionUtils
-
Unzips the input stream via a gzip filter.
- gunzip(InputStream, OutputStream) - Static method in class org.apache.druid.utils.CompressionUtils
-
gunzip from the source stream to the destination stream.
- GutmanSearchStrategy<TCoordinateArray,TPoint extends ImmutableNode<TCoordinateArray>> - 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
- GZ - org.apache.druid.utils.CompressionUtils.Format
- gzip(ByteSource, ByteSink, Predicate<Throwable>) - Static method in class org.apache.druid.utils.CompressionUtils
- gzip(File, File) - Static method in class org.apache.druid.utils.CompressionUtils
-
GZip compress the contents of inFile into outFile
- gzip(File, File, Predicate<Throwable>) - Static method in class org.apache.druid.utils.CompressionUtils
-
Gzips the input file to the output
- gzip(InputStream, OutputStream) - Static method in class org.apache.druid.utils.CompressionUtils
-
Copy inputStream to out while wrapping out in a GZIPOutputStream Closes both input and output
- GZIP - org.apache.druid.java.util.emitter.core.ContentEncoding
- GZIP - org.apache.druid.java.util.http.client.HttpClientConfig.CompressionCodec
- gzipInputStream(InputStream) - Static method in class org.apache.druid.utils.CompressionUtils
-
Fixes java bug 7036144 http://bugs.java.com/bugdatabase/view_bug.do?bug_id=7036144 which affects concatenated GZip
H
- handle(InputRow) - Method in interface org.apache.druid.data.input.HandlingInputRowIterator.InputRowHandler
- 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
- handleChunk(ClientResponse<IntermediateType>, HttpChunk, long) - Method in interface org.apache.druid.java.util.http.client.response.HttpResponseHandler
-
Called for chunked responses, indicating another HttpChunk has arrived.
- handleChunk(ClientResponse<InputStream>, HttpChunk, long) - Method in class org.apache.druid.java.util.http.client.response.SequenceInputStreamResponseHandler
- handleChunk(ClientResponse<FrameFilePartialFetch>, HttpChunk, long) - Method in class org.apache.druid.frame.file.FrameFileHttpResponseHandler
- handleChunk(ClientResponse<Either<StringFullResponseHolder, IntermediateType>>, HttpChunk, long) - Method in class org.apache.druid.java.util.http.client.response.ObjectOrErrorResponseHandler
- handleChunk(ClientResponse<AppendableByteArrayInputStream>, HttpChunk, long) - Method in class org.apache.druid.java.util.http.client.response.InputStreamResponseHandler
- handleChunk(ClientResponse<BytesFullResponseHolder>, HttpChunk, long) - Method in class org.apache.druid.java.util.http.client.response.BytesFullResponseHandler
- handleChunk(ClientResponse<InputStreamFullResponseHolder>, HttpChunk, long) - Method in class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHandler
- handleChunk(ClientResponse<StatusResponseHolder>, HttpChunk, long) - Method in class org.apache.druid.java.util.http.client.response.StatusResponseHandler
- handleChunk(ClientResponse<StringFullResponseHolder>, HttpChunk, long) - Method in class org.apache.druid.java.util.http.client.response.StringFullResponseHandler
- handledType() - Method in class org.apache.druid.java.util.common.HumanReadableBytesSerializer
- 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
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in class org.apache.druid.frame.file.FrameFileHttpResponseHandler
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in class org.apache.druid.java.util.http.client.response.BytesFullResponseHandler
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in interface org.apache.druid.java.util.http.client.response.HttpResponseHandler
-
Handles the initial HttpResponse object that comes back from Netty.
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHandler
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in class org.apache.druid.java.util.http.client.response.InputStreamResponseHandler
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in class org.apache.druid.java.util.http.client.response.ObjectOrErrorResponseHandler
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in class org.apache.druid.java.util.http.client.response.SequenceInputStreamResponseHandler
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in class org.apache.druid.java.util.http.client.response.StatusResponseHandler
- handleResponse(HttpResponse, HttpResponseHandler.TrafficCop) - Method in class org.apache.druid.java.util.http.client.response.StringFullResponseHandler
- HandlingInputRowIterator - Class in org.apache.druid.data.input
-
Decorated
CloseableIterator
that can process rows withHandlingInputRowIterator.InputRowHandler
s. - HandlingInputRowIterator(CloseableIterator<InputRow>, List<HandlingInputRowIterator.InputRowHandler>) - Constructor for class org.apache.druid.data.input.HandlingInputRowIterator
- HandlingInputRowIterator.InputRowHandler - Interface in org.apache.druid.data.input
- hasAggregators() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- hasArray() - Method in class org.apache.druid.segment.data.SafeWritableBase
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.ArrayLengthFunction
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.ArrayScalarFunction
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.ArraysFunction
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.ArraySliceFunction
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- hasArrayInputs() - Method in interface org.apache.druid.math.expr.Function
-
Returns true if a function expects any array arguments
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- hasArrayInputs() - Method in class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.ArrayAddElementFunction
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.ArrayConstructorFunction
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.ArraySliceFunction
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.ArraysMergeFunction
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- hasArrayOutput() - Method in interface org.apache.druid.math.expr.Function
-
Returns true if function produces an array.
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- hasArrayOutput() - Method in class org.apache.druid.math.expr.Function.StringToArrayFunction
- hasArrayOutput(LambdaExpr) - Method in class org.apache.druid.math.expr.ApplyFunction.BaseFoldFunction
- hasArrayOutput(LambdaExpr) - Method in class org.apache.druid.math.expr.ApplyFunction.BaseMapFunction
- hasArrayOutput(LambdaExpr) - Method in class org.apache.druid.math.expr.ApplyFunction.FilterFunction
- hasArrayOutput(LambdaExpr) - Method in interface org.apache.druid.math.expr.ApplyFunction
-
Returns true if apply function produces an array output.
- hasBitmapIndex() - Method in class org.apache.druid.data.input.impl.DimensionSchema
- 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
- hasBuiltInFilters() - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
- hasBuiltInFilters() - Method in interface org.apache.druid.segment.StorageAdapter
-
Returns true if this storage adapter can filter some rows out.
- hasByteBuffer() - Method in class org.apache.druid.segment.data.SafeWritableBase
- hasContent() - Method in class org.apache.druid.java.util.http.client.Request
- hasCustomDimensions() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- hasData() - Method in class org.apache.druid.timeline.DataSegment
- hasData() - Method in interface org.apache.druid.timeline.Overshadowable
- hasData() - Method in class org.apache.druid.timeline.partition.PartitionHolder
- hasElapsed(Duration) - Method in class org.apache.druid.java.util.common.Stopwatch
-
Checks if the given duration has already elapsed on the stopwatch.
- hasEncodingFlag(byte) - Static method in class org.apache.druid.segment.data.CompressionFactory
- hasFilters() - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
- hasFilters() - Method in class org.apache.druid.query.groupby.GroupByQuery
- hasFilters() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- hasFilters() - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- hasFilters() - Method in interface org.apache.druid.query.Query
- hasFilters() - Method in class org.apache.druid.query.scan.ScanQuery
- 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
- hasFilters(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- hasFilters(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
- hasFilters(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
-
Sets
Query.hasFilters()
of the given query as dimension. - hash(byte[]) - Method in class org.apache.druid.hll.HyperLogLogHash
- hash(byte[], int) - Method in enum org.apache.druid.timeline.partition.HashPartitionFunction
-
Returns an ID of a hash bucket for the given
serializedRow
. - hash(String) - Method in class org.apache.druid.hll.HyperLogLogHash
- HASH - org.apache.druid.indexer.partitions.SecondaryPartitionType
-
Hash partitioning partitions segments in the same time chunk based on the hash value of the partition dimensions.
- 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
- HashBasedNumberedPartialShardSpec - Class in org.apache.druid.timeline.partition
- HashBasedNumberedPartialShardSpec(List<String>, int, int, HashPartitionFunction) - Constructor for class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- HashBasedNumberedShardSpec - Class in org.apache.druid.timeline.partition
- HashBasedNumberedShardSpec(int, int, Integer, Integer, List<String>, HashPartitionFunction, ObjectMapper) - Constructor for class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- HashBucketShardSpec - Class in org.apache.druid.timeline.partition
-
See
BucketNumberedShardSpec
for how this class is used. - HashBucketShardSpec(int, int, List<String>, HashPartitionFunction, ObjectMapper) - Constructor for class org.apache.druid.timeline.partition.HashBucketShardSpec
- hashCode() - Method in class org.apache.druid.audit.AuditEntry
- hashCode() - Method in class org.apache.druid.audit.AuditEntry.Payload
- hashCode() - Method in class org.apache.druid.audit.AuditInfo
- hashCode() - Method in class org.apache.druid.audit.RequestInfo
- hashCode() - Method in class org.apache.druid.collections.RangeIntSet
- 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.common.exception.AllowedRegexErrorResponseTransformStrategy
- hashCode() - Method in class org.apache.druid.common.exception.NoErrorResponseTransformStrategy
- hashCode() - Method in class org.apache.druid.data.input.ColumnsFilter.ExclusionBased
- hashCode() - Method in class org.apache.druid.data.input.ColumnsFilter.InclusionBased
- hashCode() - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- hashCode() - Method in class org.apache.druid.data.input.impl.CloudObjectLocation
- hashCode() - Method in class org.apache.druid.data.input.impl.CombiningInputSource
- hashCode() - Method in class org.apache.druid.data.input.impl.DimensionSchema
- hashCode() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- hashCode() - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- hashCode() - Method in class org.apache.druid.data.input.impl.HttpInputSource
- hashCode() - Method in class org.apache.druid.data.input.impl.HttpInputSourceConfig
- hashCode() - Method in class org.apache.druid.data.input.impl.InlineInputSource
- hashCode() - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- hashCode() - Method in class org.apache.druid.data.input.impl.JSONParseSpec
- hashCode() - Method in class org.apache.druid.data.input.impl.LocalInputSource
- hashCode() - Method in class org.apache.druid.data.input.impl.NestedDataParseSpec
- hashCode() - Method in class org.apache.druid.data.input.impl.NestedInputFormat
- hashCode() - Method in class org.apache.druid.data.input.impl.NewSpatialDimensionSchema
- hashCode() - Method in class org.apache.druid.data.input.impl.NoopInputRowParser
- hashCode() - Method in class org.apache.druid.data.input.impl.ParseSpec
-
Deprecated.
- hashCode() - Method in class org.apache.druid.data.input.impl.SpatialDimensionSchema
-
Deprecated.
- hashCode() - Method in class org.apache.druid.data.input.impl.systemfield.SystemFields
- hashCode() - Method in class org.apache.druid.data.input.impl.TimestampSpec
- hashCode() - Method in class org.apache.druid.data.input.ListBasedInputRow
- hashCode() - Method in class org.apache.druid.data.input.MapBasedInputRow
- hashCode() - Method in class org.apache.druid.data.input.MapBasedRow
- hashCode() - Method in class org.apache.druid.data.input.MaxSizeSplitHintSpec
- hashCode() - Method in class org.apache.druid.data.input.SegmentsSplitHintSpec
- hashCode() - Method in class org.apache.druid.data.input.StringTuple
- hashCode() - Method in class org.apache.druid.extendedset.intset.AbstractIntSet
- hashCode() - Method in class org.apache.druid.extendedset.intset.ConciseSet
- hashCode() - Method in class org.apache.druid.frame.key.ByteRowKeyComparator
- hashCode() - Method in class org.apache.druid.frame.key.ClusterBy
- hashCode() - Method in class org.apache.druid.frame.key.ClusterByPartition
- hashCode() - Method in class org.apache.druid.frame.key.ClusterByPartitions
- hashCode() - Method in class org.apache.druid.frame.key.KeyColumn
- hashCode() - Method in class org.apache.druid.frame.key.RowKey
- hashCode() - Method in class org.apache.druid.frame.key.RowKeyComparator
- hashCode() - Method in class org.apache.druid.frame.key.RowKeyComparisonRunLengths
- hashCode() - Method in class org.apache.druid.frame.key.RunLengthEntry
- hashCode() - Method in class org.apache.druid.frame.processor.ReturnOrAwait
- hashCode() - Method in class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- hashCode() - Method in exception org.apache.druid.frame.write.InvalidFieldException
- hashCode() - Method in class org.apache.druid.hll.HyperLogLogCollector
- hashCode() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- hashCode() - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- hashCode() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- hashCode() - Method in class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
- hashCode() - Method in class org.apache.druid.indexer.Property
- hashCode() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- hashCode() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrorsTaskReport
- hashCode() - Method in class org.apache.druid.indexer.report.KillTaskReport
- hashCode() - Method in class org.apache.druid.indexer.report.KillTaskReport.Stats
- hashCode() - Method in class org.apache.druid.indexer.report.TaskContextReport
- hashCode() - Method in class org.apache.druid.indexer.TaskIdentifier
- hashCode() - Method in class org.apache.druid.indexer.TaskLocation
- hashCode() - Method in class org.apache.druid.indexer.TaskStatus
- hashCode() - Method in class org.apache.druid.indexer.TaskStatusPlus
- hashCode() - Method in class org.apache.druid.java.util.common.Either
- hashCode() - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- hashCode() - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- hashCode() - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- hashCode() - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- hashCode() - Method in class org.apache.druid.java.util.common.HumanReadableBytes
- hashCode() - Method in class org.apache.druid.java.util.common.NonnullPair
- hashCode() - Method in class org.apache.druid.java.util.common.Pair
- hashCode() - Method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- hashCode() - Method in class org.apache.druid.java.util.common.parsers.JSONPathSpec
- hashCode() - Method in class org.apache.druid.java.util.common.Triple
- hashCode() - Method in class org.apache.druid.js.JavaScriptConfig
- hashCode() - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- hashCode() - Method in class org.apache.druid.metadata.DefaultPasswordProvider
- hashCode() - Method in class org.apache.druid.metadata.EnvironmentVariableDynamicConfigProvider
- hashCode() - Method in class org.apache.druid.metadata.EnvironmentVariablePasswordProvider
- hashCode() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- hashCode() - Method in class org.apache.druid.metadata.TaskLookup.ActiveTaskLookup
- hashCode() - Method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- 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.ExpressionLambdaAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- hashCode() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.mean.DoubleMeanAggregatorFactory
- 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.SingleValueAggregatorFactory
- 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.ArrayContainsElementFilter
- 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.EqualityFilter.EqualityPredicateFactory
- hashCode() - Method in class org.apache.druid.query.filter.EqualityFilter
- 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.IsBooleanDimFilter
- 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.NullFilter
- hashCode() - Method in class org.apache.druid.query.filter.NullFilter.NullPredicateFactory
- hashCode() - Method in class org.apache.druid.query.filter.OrDimFilter
- hashCode() - Method in class org.apache.druid.query.filter.RangeFilter
- 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.StringPredicateDruidPredicateFactory
- hashCode() - Method in class org.apache.druid.query.filter.TrueDimFilter
- hashCode() - Method in class org.apache.druid.query.filter.TypedInFilter
- hashCode() - Method in class org.apache.druid.query.filter.TypedInFilter.PredicateFactory
- hashCode() - Method in class org.apache.druid.query.FilteredDataSource
- hashCode() - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
- hashCode() - Method in class org.apache.druid.query.groupby.epinephelinae.IntKey
- 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.operator.ColumnWithDirection
- hashCode() - Method in class org.apache.druid.query.operator.NaivePartitioningOperatorFactory
- hashCode() - Method in class org.apache.druid.query.operator.NaiveSortOperatorFactory
- hashCode() - Method in class org.apache.druid.query.operator.OffsetLimit
- hashCode() - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- hashCode() - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- hashCode() - Method in class org.apache.druid.query.operator.window.ranking.WindowRankProcessor
- hashCode() - Method in class org.apache.druid.query.operator.window.WindowFrame
- hashCode() - Method in class org.apache.druid.query.operator.window.WindowFramedAggregateProcessor
- hashCode() - Method in class org.apache.druid.query.operator.window.WindowOperatorFactory
- hashCode() - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- 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.NaturalComparator
- 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.QueryContext
- hashCode() - Method in class org.apache.druid.query.QueryDataSource
- hashCode() - Method in class org.apache.druid.query.QueryResourceId
- 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.ScanQuery.OrderBy
- 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.SegmentDescriptor
- 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.query.UnnestDataSource
- hashCode() - Method in class org.apache.druid.segment.AutoTypeColumnSchema
- hashCode() - Method in class org.apache.druid.segment.column.BaseTypeSignature
- hashCode() - Method in class org.apache.druid.segment.column.RowSignature
- hashCode() - Method in class org.apache.druid.segment.column.SimpleColumnIndexCapabilities
- hashCode() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- hashCode() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.Utf8
- 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.DataSegmentsWithSchemas
- hashCode() - Method in class org.apache.druid.segment.DefaultColumnFormatConfig
- 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.IsBooleanFilter
- 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.incremental.OnheapIncrementalIndex.Spec
- hashCode() - Method in class org.apache.druid.segment.incremental.ParseExceptionReport
- hashCode() - Method in class org.apache.druid.segment.incremental.RowIngestionMetersTotals
- 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.nested.FieldTypeInfo.MutableTypeSet
- hashCode() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.TypeSet
- hashCode() - Method in class org.apache.druid.segment.nested.NestedPathArrayElement
- hashCode() - Method in class org.apache.druid.segment.nested.NestedPathField
- hashCode() - Method in class org.apache.druid.segment.nested.StructuredData
- hashCode() - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessedValue
- hashCode() - Method in class org.apache.druid.segment.NestedDataColumnSchema
- hashCode() - Method in class org.apache.druid.segment.SchemaPayload
- hashCode() - Method in class org.apache.druid.segment.SchemaPayloadPlus
- hashCode() - Method in class org.apache.druid.segment.SegmentMetadata
- hashCode() - Method in class org.apache.druid.segment.SegmentSchemaMapping
- hashCode() - Method in class org.apache.druid.segment.serde.NullColumnPartSerde
- 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.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.virtual.ListFilteredVirtualColumn
- hashCode() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- hashCode() - Method in class org.apache.druid.segment.VirtualColumns
- hashCode() - Method in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- hashCode() - Method in class org.apache.druid.storage.local.LocalFileStorageConnectorProvider
- hashCode() - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters
- hashCode() - Method in class org.apache.druid.timeline.CompactionState
- hashCode() - Method in class org.apache.druid.timeline.DataSegment
- hashCode() - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- hashCode() - Method in class org.apache.druid.timeline.partition.LinearPartitionChunk
- hashCode() - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- hashCode() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- hashCode() - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- hashCode() - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.PartitionBoundaries
- hashCode() - Method in class org.apache.druid.timeline.partition.PartitionHolder
- hashCode() - Method in class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- hashCode() - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- hashCode() - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- hashCode() - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- hashCode() - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- hashCode() - Method in class org.apache.druid.timeline.SegmentId
- hashCode() - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- hashCode() - Method in class org.apache.druid.timeline.TimelineObjectHolder
- hashCode() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline.TimelineEntry
- hashCode(Double) - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- hashCode(Float) - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- hashCode(Long) - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- hashCode(Object[]) - Method in class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
-
Implements
Arrays.hashCode(Object[])
but the element hashing uses the element's type strategy - hashCode(String) - Method in class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- hashCode(T) - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- hashCode(T) - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- hashCode(T) - Method in interface org.apache.druid.segment.column.TypeStrategy
- HASHED - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- HashedPartitionsSpec - Class in org.apache.druid.indexer.partitions
- HashedPartitionsSpec(Integer, Integer, List<String>) - Constructor for class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- HashedPartitionsSpec(Integer, Integer, List<String>, HashPartitionFunction) - Constructor for class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- HashedPartitionsSpec(Integer, Integer, List<String>, HashPartitionFunction, Integer, Integer) - Constructor for class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- 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
- hashIds(List<DataSegment>) - Static method in class org.apache.druid.segment.SegmentUtils
-
Hash the IDs of the given segments based on SHA-256 algorithm.
- 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, Filter, 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
- HashPartitioner - Class in org.apache.druid.timeline.partition
-
This class is used for hash partitioning during ingestion.
- HashPartitionFunction - Enum in org.apache.druid.timeline.partition
-
An enum of supported hash partition functions.
- 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
- 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.
- 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(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
- 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.
- HashVectorGrouper - Class in org.apache.druid.query.groupby.epinephelinae
-
An implementation of
VectorGrouper
backed by a growableMemoryOpenHashTable
. - HashVectorGrouper(Supplier<ByteBuffer>, int, AggregatorAdapters, int, float, int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
- hasIndex() - Method in class org.apache.druid.query.filter.FilterBundle
- hasInputArrays() - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Returns true if any expression in the expression tree has any array inputs.
- hasLimit() - Method in class org.apache.druid.query.operator.OffsetLimit
- hasLowerBound() - Method in class org.apache.druid.query.filter.BoundDimFilter
- hasLowerBound() - Method in class org.apache.druid.query.filter.RangeFilter
- hasMatch() - Method in interface org.apache.druid.segment.join.JoinMatcher
-
Returns whether the active matcher (
JoinMatcher.matchCondition()
orJoinMatcher.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
- hasMatcher() - Method in class org.apache.druid.query.filter.FilterBundle
- hasMore() - Method in interface org.apache.druid.data.input.Firehose
-
Deprecated.Returns whether there are more rows to process.
- 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.StringUtf8DictionaryEncodedColumn
- hasMultipleValues() - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- hasMultipleValues() - Method in class org.apache.druid.segment.nested.VariantColumn
- hasMultipleValues(boolean) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- hasMultipleValues(RowKey, int) - Method in class org.apache.druid.frame.key.RowKeyReader
-
Determine if a particular field of a particular key has multiple values.
- hasNestedData - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
-
Have we seen any objects? Empty objects in particular are sneaky, they don't have any nested paths, so we also broadly track if we have processed any objects
StructuredDataProcessor.ProcessResults.hasObjects()
- 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.CombiningIterator
- hasNext() - Method in class org.apache.druid.collections.IntegerSet.BitSetIterator
- hasNext() - Method in class org.apache.druid.data.input.HandlingInputRowIterator
- hasNext() - Method in class org.apache.druid.data.input.impl.FastLineIterator
- hasNext() - Method in class org.apache.druid.data.input.impl.prefetch.JsonIterator
-
Returns
true
if there are more objects to be read. - hasNext() - Method in class org.apache.druid.extendedset.intset.BitIterator
- hasNext() - Method in class org.apache.druid.extendedset.intset.EmptyIntIterator
- hasNext() - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet.WordIterator
- hasNext() - Method in interface org.apache.druid.extendedset.intset.IntSet.IntIterator
- hasNext() - Method in class org.apache.druid.frame.channel.FrameChannelSequence.FrameChannelIterator
- hasNext() - Method in class org.apache.druid.java.util.common.guava.DroppingIterator
- hasNext() - Method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- hasNext() - Method in class org.apache.druid.java.util.common.guava.MergeIterator
- hasNext() - Method in class org.apache.druid.java.util.common.guava.nary.TrinaryTransformIterator
- 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.query.scan.ScanResultValueIterator
- hasNext() - Method in class org.apache.druid.segment.AutoTypeColumnMerger.ArrayDictionaryMergingIterator
- hasNext() - Method in class org.apache.druid.segment.AutoTypeColumnMerger.IdLookupArrayIterator
- hasNext() - Method in class org.apache.druid.segment.DictionaryMergingIterator
- hasNext() - Method in interface org.apache.druid.segment.serde.cell.IOIterator
- hasNext() - Method in class org.apache.druid.segment.SimpleDictionaryMergingIterator
- hasNonNullKeyParts(int, int[]) - Method in interface org.apache.druid.frame.key.FrameComparisonWidget
-
Whether particular key parts in a particular row are non-null.
- hasNonNullKeyParts(int, int[]) - Method in class org.apache.druid.frame.key.FrameComparisonWidgetImpl
- hasNotElapsed(Duration) - Method in class org.apache.druid.java.util.common.Stopwatch
-
Checks that the given duration has not elapsed on the stopwatch.
- hasNull - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- hasNull - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- hasNulls - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
-
have we seen any null values?
- hasNulls - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- hasNulls - Variable in class org.apache.druid.segment.NestedDataColumnIndexerV4
- hasNulls() - Method in interface org.apache.druid.segment.column.ColumnCapabilities.CoercionLogic
-
If
ColumnCapabilities.hasNulls()
isColumnCapabilities.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
- hasNulls() - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- hasNulls() - Method in class org.apache.druid.segment.nested.NestedDataColumnMetadata
- hasNulls() - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- hasNulls() - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- hasNulls() - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- hasNulls(boolean) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- hasObjects() - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
-
Returns true if
- hasOffset() - Method in class org.apache.druid.query.operator.OffsetLimit
- hasOnlyNulls() - Method in class org.apache.druid.segment.AutoTypeColumnMerger
- hasOnlyNulls() - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- hasOnlyNulls() - Method in interface org.apache.druid.segment.DimensionMerger
-
Returns true if this dimension has no data besides nulls.
- hasOnlyNulls() - Method in class org.apache.druid.segment.NestedDataColumnMergerV4
- hasOnlyNulls() - Method in class org.apache.druid.segment.NumericDimensionMergerV9
- hasParseException() - Method in class org.apache.druid.segment.incremental.IncrementalIndexAddResult
- hasQueryGranularity() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- hasRemaining() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- 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
- hasTaskCreatedTimeFilter() - Method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- 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 whichRowIterator.getPointer()
currently points. - hasTimeout() - Method in class org.apache.druid.query.QueryContext
- hasTimestampSpec() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- hasUntypedArray() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- hasUpperBound() - Method in class org.apache.druid.query.filter.BoundDimFilter
- hasUpperBound() - Method in class org.apache.druid.query.filter.RangeFilter
- hasValueCardinalityThreshold() - Method in class org.apache.druid.query.filter.FilterTuning
- 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_LAST_FETCH_NAME - Static variable in class org.apache.druid.frame.file.FrameFileHttpResponseHandler
- HEADER_LAST_FETCH_VALUE - Static variable in class org.apache.druid.frame.file.FrameFileHttpResponseHandler
- HEADER_NUM_BYTES - Static variable in class org.apache.druid.collections.spatial.ImmutableFloatNode
- HEADER_NUM_BYTES - Static variable in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- HEADER_NUM_BYTES - Static variable in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- HEADER_SIZE - Static variable in class org.apache.druid.frame.Frame
- headSet(int) - Method in class org.apache.druid.collections.RangeIntSet
- 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
- HeapMemoryAllocator - Class in org.apache.druid.frame.allocation
-
Allocator that uses
ByteBuffer.allocate(int)
to create chunks in the JVM heap. - HIGH_CORRECTION_THRESHOLD - Static variable in class org.apache.druid.hll.HyperLogLogCollector
- 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
- HISTORICAL_NULL - Static variable in interface org.apache.druid.indexer.partitions.PartitionsSpec
- 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 fromHistoricalCursor
. - HistoricalSingleValueDimSelector1SimpleDoubleAggPooledTopNScannerPrototype - Class in org.apache.druid.query.topn
- HistoricalSingleValueDimSelector1SimpleDoubleAggPooledTopNScannerPrototype() - Constructor for class org.apache.druid.query.topn.HistoricalSingleValueDimSelector1SimpleDoubleAggPooledTopNScannerPrototype
- HIVE - org.apache.druid.java.util.common.granularity.Granularity.Formatter
- 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
- HllAddExprMacro() - Constructor for class org.apache.druid.query.expression.HyperUniqueExpressions.HllAddExprMacro
- HllCreateExprMacro() - Constructor for class org.apache.druid.query.expression.HyperUniqueExpressions.HllCreateExprMacro
- HllEstimateExprMacro() - Constructor for class org.apache.druid.query.expression.HyperUniqueExpressions.HllEstimateExprMacro
- HllRoundEstimateExprMacro() - Constructor for class org.apache.druid.query.expression.HyperUniqueExpressions.HllRoundEstimateExprMacro
- HOMOGENIZE_NULL_MULTIVALUE_STRING_ARRAYS - Static variable in class org.apache.druid.math.expr.ExpressionProcessingConfig
- HotLoopCallee - Interface in org.apache.druid.query.monomorphicprocessing
-
Marker interface for abstractions, which are called from hot loops during query processing.
- HOUR - org.apache.druid.java.util.common.granularity.GranularityType
- HOUR - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- HOUR - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- HttpClient - Interface in org.apache.druid.java.util.http.client
-
Interface for Async HTTP client libraries.
- HttpClientConfig - Class in org.apache.druid.java.util.http.client
- HttpClientConfig.Builder - Class in org.apache.druid.java.util.http.client
- HttpClientConfig.CompressionCodec - Enum in org.apache.druid.java.util.http.client
- HttpClientInit - Class in org.apache.druid.java.util.http.client
- HttpClientInit() - Constructor for class org.apache.druid.java.util.http.client.HttpClientInit
- HttpClientPipelineFactory - Class in org.apache.druid.java.util.http.client.netty
- HttpClientPipelineFactory() - Constructor for class org.apache.druid.java.util.http.client.netty.HttpClientPipelineFactory
- HttpClientProxyConfig - Class in org.apache.druid.java.util.http.client
- HttpClientProxyConfig() - Constructor for class org.apache.druid.java.util.http.client.HttpClientProxyConfig
- HttpClientProxyConfig(String, int, String, String) - Constructor for class org.apache.druid.java.util.http.client.HttpClientProxyConfig
- HttpEmitterConfig - Class in org.apache.druid.java.util.emitter.core
- HttpEmitterConfig() - Constructor for class org.apache.druid.java.util.emitter.core.HttpEmitterConfig
-
For JSON deserialization only.
- HttpEmitterConfig(BaseHttpEmittingConfig, String) - Constructor for class org.apache.druid.java.util.emitter.core.HttpEmitterConfig
- HttpEmitterConfig.Builder - Class in org.apache.druid.java.util.emitter.core
- HttpEmitterFactory - Class in org.apache.druid.java.util.emitter.factory
- HttpEmitterFactory() - Constructor for class org.apache.druid.java.util.emitter.factory.HttpEmitterFactory
- HttpEntity - Class in org.apache.druid.data.input.impl
- HttpInputSource - Class in org.apache.druid.data.input.impl
- HttpInputSource(List<URI>, String, PasswordProvider, SystemFields, HttpInputSourceConfig) - Constructor for class org.apache.druid.data.input.impl.HttpInputSource
- HttpInputSourceConfig - Class in org.apache.druid.data.input.impl
- HttpInputSourceConfig(Set<String>) - Constructor for class org.apache.druid.data.input.impl.HttpInputSourceConfig
- HttpPostEmitter - Class in org.apache.druid.java.util.emitter.core
- HttpPostEmitter(HttpEmitterConfig, AsyncHttpClient) - Constructor for class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- HttpPostEmitter(HttpEmitterConfig, AsyncHttpClient, ObjectMapper) - Constructor for class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- HttpPostEmitterMonitor - Class in org.apache.druid.java.util.metrics
- HttpPostEmitterMonitor(String, HttpPostEmitter, ImmutableMap<String, String>) - Constructor for class org.apache.druid.java.util.metrics.HttpPostEmitterMonitor
- HttpResponseHandler<IntermediateType,FinalType> - Interface in org.apache.druid.java.util.http.client.response
-
A handler for an HTTP request.
- HttpResponseHandler.TrafficCop - Interface in org.apache.druid.java.util.http.client.response
- HumanReadableBinaryByteFormatFunc() - Constructor for class org.apache.druid.math.expr.Function.HumanReadableBinaryByteFormatFunc
- HumanReadableBytes - Class in org.apache.druid.java.util.common
- HumanReadableBytes(long) - Constructor for class org.apache.druid.java.util.common.HumanReadableBytes
- HumanReadableBytes(String) - Constructor for class org.apache.druid.java.util.common.HumanReadableBytes
- HumanReadableBytes.UnitSystem - Enum in org.apache.druid.java.util.common
- HumanReadableBytesRange - Annotation Type in org.apache.druid.java.util.common
-
This annotation is an extension of java validation framework to ensure the validity of value of
HumanReadableBytes
. - HumanReadableBytesRange.HumanReadableBytesRangeValidator - Class in org.apache.druid.java.util.common
- HumanReadableBytesRangeValidator() - Constructor for class org.apache.druid.java.util.common.HumanReadableBytesRange.HumanReadableBytesRangeValidator
- HumanReadableBytesSerializer - Class in org.apache.druid.java.util.common
-
This serializer provides the basic support of JSON serialization of
HumanReadableBytes
to demonstrate serialization and deserialization work Given - HumanReadableBytesSerializer() - Constructor for class org.apache.druid.java.util.common.HumanReadableBytesSerializer
- HumanReadableDecimalByteFormatFunc() - Constructor for class org.apache.druid.math.expr.Function.HumanReadableDecimalByteFormatFunc
- HumanReadableDecimalFormatFunc() - Constructor for class org.apache.druid.math.expr.Function.HumanReadableDecimalFormatFunc
- HYPER_UNIQUE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- HyperLogLogCollector - Class in org.apache.druid.hll
-
Implements the HyperLogLog cardinality estimator described in: http://algo.inria.fr/flajolet/Publications/FlFuGaMe07.pdf Run this code to see a simple indication of expected errors based on different m values:
for (int i = 1; i < 20; ++i) { System.out.printf("i[%,d], val[%,d] => error[%f%%]%n", i, 2 << i, 104 / Math.sqrt(2 << i)); }
This class is *not* multi-threaded. - HyperLogLogCollector(ByteBuffer) - Constructor for class org.apache.druid.hll.HyperLogLogCollector
- HyperLogLogCollectorAggregateCombiner - Class in org.apache.druid.query.aggregation.cardinality
- HyperLogLogCollectorAggregateCombiner() - Constructor for class org.apache.druid.query.aggregation.cardinality.HyperLogLogCollectorAggregateCombiner
- HyperLogLogHash - Class in org.apache.druid.hll
-
Contains data hashing methods used before applying Hyper Log Log.
- HyperLogLogHash(HashFunction) - Constructor for class org.apache.druid.hll.HyperLogLogHash
- HyperUniqueExpressions - Class in org.apache.druid.query.expression
- HyperUniqueExpressions() - Constructor for class org.apache.druid.query.expression.HyperUniqueExpressions
- HyperUniqueExpressions.HllAddExprMacro - Class in org.apache.druid.query.expression
- HyperUniqueExpressions.HllCreateExprMacro - Class in org.apache.druid.query.expression
- HyperUniqueExpressions.HllEstimateExprMacro - Class in org.apache.druid.query.expression
- HyperUniqueExpressions.HllRoundEstimateExprMacro - Class in org.apache.druid.query.expression
- 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) - Constructor for class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
- HyperUniquesAggregatorFactory(String, String, boolean, boolean) - 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
- hypot(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Hypot() - Constructor for class org.apache.druid.math.expr.Function.Hypot
I
- IAE - Exception in org.apache.druid.java.util.common
- IAE(String, Object...) - Constructor for exception org.apache.druid.java.util.common.IAE
- IAE(Throwable, String, Object...) - Constructor for exception org.apache.druid.java.util.common.IAE
- ID - Static variable in class org.apache.druid.query.DruidMetrics
- identifier(Expr.VectorInputBindingInspector, String) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Creates an
ExprVectorProcessor
that creates aExprEvalVector
for some expression variable input binding, typically for segment column value vectors from aVectorValueSelector
orVectorObjectSelector
. - IDENTIFIER - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression is a simple identifier expression, do not transform
- IDENTIFIER - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- IDENTIFIER - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- IDENTIFIER() - Method in class org.apache.druid.math.expr.antlr.ExprParser.ApplyFunctionExprContext
- IDENTIFIER() - Method in class org.apache.druid.math.expr.antlr.ExprParser.FunctionExprContext
- IDENTIFIER() - Method in class org.apache.druid.math.expr.antlr.ExprParser.IdentifierExprContext
- IDENTIFIER() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LambdaContext
- IDENTIFIER(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LambdaContext
- IdentifierExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.IdentifierExprContext
- 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
- IDENTITY - org.apache.druid.java.util.http.client.HttpClientConfig.CompressionCodec
- 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.column.StringUtf8DictionaryEncodedColumn.StringMultiValueDimensionVectorSelector
- idLookup() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringSingleValueDimensionVectorSelector
- idLookup() - Method in class org.apache.druid.segment.ConstantDimensionSelector
- idLookup() - Method in class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- idLookup() - Method in interface org.apache.druid.segment.DimensionDictionarySelector
-
Returns
IdLookup
if available for this DimensionSelector, or null. - 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.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- idLookup() - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector
- IdLookup - Interface in org.apache.druid.segment
-
"Mixin" for
DimensionSelector
. - IdLookupArrayIterator(DictionaryIdLookup, Iterator<Object[]>) - Constructor for class org.apache.druid.segment.AutoTypeColumnMerger.IdLookupArrayIterator
- IdMapping - Class in org.apache.druid.segment
-
Map some set of dictionary id to a smaller set of dictionaryIds (or...
- IdMapping.Builder - Class in org.apache.druid.segment
- idToKey(int) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.DimensionIdCodec
- IdUtils - Class in org.apache.druid.common.utils
- IdUtils() - Constructor for class org.apache.druid.common.utils.IdUtils
- 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
- ignoreNullsForStringCardinality() - Static method in class org.apache.druid.common.config.NullHandling
-
whether nulls should be counted during String cardinality
- immediatelyReadablePair(WritableFrameChannel, MemoryAllocator, ReadableFrameChannel, int) - Static method in class org.apache.druid.frame.processor.OutputChannel
-
Creates an output channel pair, where the readable channel is usable before writing is complete.
- 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
- ImmutableConciseSet - Class in org.apache.druid.extendedset.intset
- ImmutableConciseSet() - Constructor for class org.apache.druid.extendedset.intset.ImmutableConciseSet
- ImmutableConciseSet(IntBuffer) - Constructor for class org.apache.druid.extendedset.intset.ImmutableConciseSet
- ImmutableConciseSet.WordIterator - Class in org.apache.druid.extendedset.intset
- ImmutableFloatNode - 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.
- ImmutableFloatNode(int, int, int, short, boolean, ByteBuffer, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.ImmutableFloatNode
- ImmutableFloatNode(int, int, int, ByteBuffer, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.ImmutableFloatNode
- ImmutableFloatPoint - Class in org.apache.druid.collections.spatial
- ImmutableFloatPoint(int, int, int, ByteBuffer, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.ImmutableFloatPoint
- ImmutableFloatPoint(ImmutableNode) - Constructor for class org.apache.druid.collections.spatial.ImmutableFloatPoint
- ImmutableLookupMap - Class in org.apache.druid.query.lookup
-
Similar to
MapLookupExtractor
, but immutable, and also reversible without iterating the entire map. - ImmutableLookupMap.ImmutableLookupExtractor - Class in org.apache.druid.query.lookup
- ImmutableNode<TCoordinatesArray> - Interface in org.apache.druid.collections.spatial
- 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
- IN_SUB_QUERY_THRESHOLD_KEY - Static variable in class org.apache.druid.query.QueryContexts
- 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
- includeInHeader() - Method in class org.apache.druid.query.context.ResponseContext.AbstractKey
- includeInHeader() - Method in interface org.apache.druid.query.context.ResponseContext.Key
-
Whether to return the key, value pair in the response header.
- 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 withprefix
and has at least one other character beyond that). - inclusionBased(Set<String>) - Static method in class org.apache.druid.data.input.ColumnsFilter
-
Accepts a specific list of columns.
- IncompatibleTypeException(TypeSignature<?>, TypeSignature<?>) - Constructor for exception org.apache.druid.segment.column.Types.IncompatibleTypeException
- INCOMPLETE_INPUTS - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression has inputs whose type was incomplete, such as unknown multi-valuedness, which are not explicitly used as possibly multi-valued/array inputs
- INCOMPLETE_OK - org.apache.druid.timeline.Partitions
-
Specifies that complete as well as incomplete partitions should be considered.
- increment() - Method in class org.apache.druid.collections.ReferenceCountingResourceHolder
-
Increments the reference count by 1 and returns a
ResourceHolder
representing the new references. - increment() - Method in class org.apache.druid.concurrent.ConcurrentAwaitableCounter
-
Increment the count.
- increment() - Method in class org.apache.druid.frame.segment.FrameFilteredOffset
- 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
- increment(long) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- increment(long) - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- increment(long) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- increment(long) - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- increment(long) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- increment(DateTime) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- increment(DateTime) - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- increment(DateTime) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- increment(DateTime) - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- increment(DateTime) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- IncrementalIndex - Class in org.apache.druid.segment.incremental
-
In-memory, row-based data structure used to hold data during ingestion.
- IncrementalIndex(IncrementalIndexSchema, boolean, boolean) - Constructor for class org.apache.druid.segment.incremental.IncrementalIndex
- IncrementalIndex.DimensionDesc - Class in org.apache.druid.segment.incremental
- IncrementalIndex.FactsHolder - Interface in org.apache.druid.segment.incremental
- IncrementalIndex.InputRowHolder - 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) - 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, ParseException) - 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 is a simple
IncrementalIndexRowHolder.get()
/IncrementalIndexRowHolder.set(org.apache.druid.segment.incremental.IncrementalIndexRow)
holder ofIncrementalIndexRow
. - IncrementalIndexRowHolder() - Constructor for class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
- incrementalIndexSchema - Variable in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- 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
- incrementAndCheckPosition(long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- incrementPosition(long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- incrementProcessed() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
- incrementProcessed() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
- incrementProcessed() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- incrementProcessedBytes(long) - Method in interface org.apache.druid.data.input.InputStats
- incrementProcessedBytes(long) - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
- incrementProcessedBytes(long) - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- incrementProcessedWithError() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
- incrementProcessedWithError() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
- incrementProcessedWithError() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- incrementReferenceAndDecrementOnceCloseable() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
-
Returns an
Optional
of aCloseable
fromReferenceCountingCloseableObject.decrementOnceCloseable()
, if it is able to successfullyReferenceCountingCloseableObject.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
- incrementThrownAway() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- incrementUnparseable() - Method in class org.apache.druid.segment.incremental.NoopRowIngestionMeters
- incrementUnparseable() - Method in interface org.apache.druid.segment.incremental.RowIngestionMeters
- incrementUnparseable() - Method in class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- IndexableAdapter - Interface in org.apache.druid.segment
-
An adapter to an index
- IndexableAdapter.NestedColumnMergable - Class in org.apache.druid.segment
- IndexBundleInfo(Supplier<String>, int, long, List<FilterBundle.IndexBundleInfo>) - Constructor for class org.apache.druid.query.filter.FilterBundle.IndexBundleInfo
- Indexed<T> - Interface in org.apache.druid.segment.data
-
Indexed is a fixed-size, immutable, indexed set of values which allows locating a specific index via an exact match, the semantics of which are defined by the implementation.
- 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
- IndexedStringDictionaryEncodedStringValueIndex<TDictionary extends Indexed<String>> - Class in org.apache.druid.segment.index
- IndexedStringDictionaryEncodedStringValueIndex(BitmapFactory, TDictionary, Indexed<ImmutableBitmap>) - Constructor for class org.apache.druid.segment.index.IndexedStringDictionaryEncodedStringValueIndex
- IndexedStringDruidPredicateIndexes<TDictionary extends Indexed<String>> - Class in org.apache.druid.segment.index
- IndexedStringDruidPredicateIndexes(BitmapFactory, TDictionary, Indexed<ImmutableBitmap>) - Constructor for class org.apache.druid.segment.index.IndexedStringDruidPredicateIndexes
- 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
- IndexedUtf8LexicographicalRangeIndexes<TDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.index
- IndexedUtf8LexicographicalRangeIndexes(BitmapFactory, TDictionary, Indexed<ImmutableBitmap>, boolean) - Constructor for class org.apache.druid.segment.index.IndexedUtf8LexicographicalRangeIndexes
- IndexedUtf8ValueIndexes<TDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.index
- IndexedUtf8ValueIndexes(BitmapFactory, TDictionary, Indexed<ImmutableBitmap>) - Constructor for class org.apache.druid.segment.index.IndexedUtf8ValueIndexes
- indexerProcessor - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
- indexerProcessor - Variable in class org.apache.druid.segment.NestedDataColumnIndexerV4
- 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
- IndexMergerV9 - Class in org.apache.druid.segment
- IndexMergerV9(ObjectMapper, IndexIO, SegmentWriteOutMediumFactory) - Constructor for class org.apache.druid.segment.IndexMergerV9
-
This constructor is used only for Hadoop ingestion and Tranquility as they do not support storing empty columns yet.
- IndexMergerV9(ObjectMapper, IndexIO, SegmentWriteOutMediumFactory, boolean) - Constructor for class org.apache.druid.segment.IndexMergerV9
- IndexMergerV9Factory - Class in org.apache.druid.segment
- IndexMergerV9Factory(ObjectMapper, IndexIO, SegmentWriteOutMediumFactory) - Constructor for class org.apache.druid.segment.IndexMergerV9Factory
- indexOf(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
- indexOf(int[]) - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexed
- indexOf(Object) - Method in class org.apache.druid.math.expr.CartesianList
- 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(String) - Method in class org.apache.druid.segment.column.StringEncodingStrategies.Utf8ToStringIndexed
- indexOf(ByteBuffer) - Method in class org.apache.druid.segment.data.FrontCodedIndexed
- indexOf(IndexedInts) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
- indexOf(IndexedInts) - Method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
- indexOf(IndexedInts) - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- indexOf(T) - Method in class org.apache.druid.segment.data.FixedIndexed
- indexOf(T) - Method in class org.apache.druid.segment.data.GenericIndexed.BufferIndexed
- 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(T) - Method in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
- indexOf(T) - Method in class org.apache.druid.segment.serde.ReplaceFirstValueWithNullIndexed
- 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.DictionaryEncodedColumnMerger.IndexSeekerWithoutConversion
- IndexSizeExceededException - Exception in org.apache.druid.segment.incremental
- IndexSizeExceededException(String, Object...) - Constructor for exception org.apache.druid.segment.incremental.IndexSizeExceededException
- indexSpec - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- indexSpec - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- indexSpec - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- indexSpec - Variable in class org.apache.druid.segment.NumericDimensionMergerV9
- 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(BitmapSerdeFactory, CompressionStrategy, StringEncodingStrategy, CompressionStrategy, CompressionFactory.LongEncodingStrategy, CompressionStrategy, SegmentizerFactory) - Constructor for class org.apache.druid.segment.IndexSpec
-
Creates an IndexSpec with the given storage format settings.
- IndexSpec.Builder - Class in org.apache.druid.segment
- IndexWriter - Class in org.apache.druid.segment.serde.cell
- IndexWriter(WriteOutBytes, NumberSerializer) - Constructor for class org.apache.druid.segment.serde.cell.IndexWriter
- IndexWriter(WriteOutBytes, NumberSerializer, NumberSerializer) - Constructor for class org.apache.druid.segment.serde.cell.IndexWriter
- InDimFilter - Class in org.apache.druid.query.filter
-
Approximately like the SQL 'IN' filter, with the main difference being that this will match NULL values if contained in the values list instead of ignoring them.
- InDimFilter(String, Collection<String>, ExtractionFn) - Constructor for class org.apache.druid.query.filter.InDimFilter
-
Creates a new filter without an extraction function or any special filter tuning.
- InDimFilter(String, Set<String>) - Constructor for class org.apache.druid.query.filter.InDimFilter
-
Creates a new filter without an extraction function or any special filter tuning.
- InDimFilter(String, InDimFilter.ValuesSet, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.query.filter.InDimFilter
-
Creates a new filter.
- InDimFilter.InFilterDruidPredicateFactory - Class in org.apache.druid.query.filter
- InDimFilter.ValuesSet - Class in org.apache.druid.query.filter
- inferColumnCapabilities(ColumnType) - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
Tries to construct the most appropriate
ColumnCapabilities
for this plan given theExpressionPlan.outputType
andExpressionPlan.traits
inferred by theExpressionPlanner
, optionally with the help of hintValueType
. - inferTzFromString(String) - Static method in class org.apache.druid.java.util.common.DateTimes
- inferTzFromString(String, boolean) - Static method in class org.apache.druid.java.util.common.DateTimes
- InFilterDruidPredicateFactory(ExtractionFn, InDimFilter.ValuesSet) - Constructor for class org.apache.druid.query.filter.InDimFilter.InFilterDruidPredicateFactory
- info(String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- info(Throwable, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- info(Marker, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- INFO - org.apache.druid.java.util.emitter.core.LoggingEmitter.Level
- infoSegmentIds(Stream<SegmentId>, String) - Method in class org.apache.druid.java.util.common.logger.Logger
- infoSegments(Collection<DataSegment>, String) - Method in class org.apache.druid.java.util.common.logger.Logger
- IngestionState - Enum in org.apache.druid.indexer
- IngestionStatsAndErrors - Class in org.apache.druid.indexer.report
- IngestionStatsAndErrors(IngestionState, Map<String, Object>, Map<String, Object>, String, boolean, long, Map<String, Long>, Long, Long) - Constructor for class org.apache.druid.indexer.report.IngestionStatsAndErrors
- IngestionStatsAndErrorsTaskReport - Class in org.apache.druid.indexer.report
- IngestionStatsAndErrorsTaskReport(String, IngestionStatsAndErrors) - Constructor for class org.apache.druid.indexer.report.IngestionStatsAndErrorsTaskReport
- 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(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.NilVectorAggregator
- 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.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 correspondingAggregatorFactory
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityBufferAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityVectorAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantBufferAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.constant.LongConstantVectorAggregator
- 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.ExpressionLambdaBufferAggregator
- 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.firstlast.DoubleFirstLastVectorAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.NumericFirstBufferAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.NumericLastBufferAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.SingleStringFirstLastDimensionVectorAggregator
- init(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastVectorAggregator
- 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.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.SingleValueBufferAggregator
- 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 - org.apache.druid.java.util.common.lifecycle.Lifecycle.Stage
- INIT - Static variable in interface org.apache.druid.segment.RowIdSupplier
-
A number that will never be returned from
RowIdSupplier.getRowId()
. - 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[], IncrementalIndex.InputRowHolder) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- initAggs(AggregatorFactory[], IncrementalIndex.InputRowHolder) - 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.FixedWidthGroupByColumnSelectorStrategy
- 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.KeyMappingMultiValueGroupByColumnSelectorStrategy.DictionaryBuilding
- initColumnValues(ColumnValueSelector, int, Object[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.PrebuiltDictionary
- initGroupingKeyColumnValue(int, int, Object, ByteBuffer, int[]) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FixedWidthGroupByColumnSelectorStrategy
- 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.KeyMappingMultiValueGroupByColumnSelectorStrategy
- initialBuckets - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- initialBuckets - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- initialize() - Method in class org.apache.druid.common.config.Log4jShutdown
- initialize() - Method in class org.apache.druid.query.context.ResponseContext
-
Initialize fields for a query context.
- initialize() - Method in interface org.apache.druid.segment.DictionaryEncodedColumnMerger.ExtendedIndexesMerger
- initialize() - Method in class org.apache.druid.segment.StringDimensionMergerV9.SpatialIndexesMerger
- initialize(HumanReadableBytesRange) - Method in class org.apache.druid.java.util.common.HumanReadableBytesRange.HumanReadableBytesRangeValidator
- initializeForHomogenizeNullMultiValueStrings() - Static method in class org.apache.druid.math.expr.ExpressionProcessing
- initializeForStrictBooleansTests(boolean) - Static method in class org.apache.druid.math.expr.ExpressionProcessing
- initializeForTests() - Static method in class org.apache.druid.common.config.NullHandling
-
Many unit tests do not setup modules for this value to be injected, this method provides a manual way to initialize
NullHandling.INSTANCE
- initializeForTests() - Static method in class org.apache.druid.math.expr.ExpressionProcessing
-
Many unit tests do not setup modules for this value to be injected, this method provides a manual way to initialize
ExpressionProcessing.INSTANCE
- initializeForTestsWithValues(Boolean, Boolean) - Static method in class org.apache.druid.common.config.NullHandling
- initializeForTestsWithValues(Boolean, Boolean, Boolean) - Static method in class org.apache.druid.common.config.NullHandling
- initializeMissingSegments() - Method in class org.apache.druid.query.context.ResponseContext
- initializeNewBucketKey(int, ByteBuffer, int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- initializeParser() - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- initializeRemainingResponses() - Method in class org.apache.druid.query.context.ResponseContext
- initializeRowScanCount() - Method in class org.apache.druid.query.context.ResponseContext
- 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
- initValue() - Method in interface org.apache.druid.query.aggregation.firstlast.SelectionPredicate
- 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.
- inject(Properties, JsonConfigurator) - Method in class org.apache.druid.guice.JsonConfigProvider
- inject(ConfigurationObjectFactory) - Method in class org.apache.druid.guice.ConfigProvider
-
Deprecated.
- InlineDataSource - Class in org.apache.druid.query
-
Represents an inline datasource, where the rows are embedded within the DataSource object itself.
- InlineInputSource - Class in org.apache.druid.data.input.impl
- InlineInputSource(String) - Constructor for class org.apache.druid.data.input.impl.InlineInputSource
- InlineJoinableFactory - Class in org.apache.druid.segment.join
-
A
JoinableFactory
forInlineDataSource
. - InlineJoinableFactory() - Constructor for class org.apache.druid.segment.join.InlineJoinableFactory
- INNER - org.apache.druid.segment.join.JoinType
- InputBindings - Class in org.apache.druid.math.expr
- InputBindings() - Constructor for class org.apache.druid.math.expr.InputBindings
- InputBindings.BestEffortInputBindings - Class in org.apache.druid.math.expr
-
Expr.ObjectBinding
backed by a cache populated byExprEval.bestEffortOf(Object)
for when the input type information is totally unknown, for a single row worth of values. - InputBindings.InputSupplier<T> - Class in org.apache.druid.math.expr
- inputChannels() - Method in class org.apache.druid.frame.processor.FrameChannelBatcher
- inputChannels() - Method in class org.apache.druid.frame.processor.FrameChannelHashPartitioner
- inputChannels() - Method in class org.apache.druid.frame.processor.FrameChannelMerger
- inputChannels() - Method in class org.apache.druid.frame.processor.FrameChannelMixer
- inputChannels() - Method in interface org.apache.druid.frame.processor.FrameProcessor
-
List of input channels.
- InputEntity - Interface in org.apache.druid.data.input
-
InputEntity abstracts an input entity and knows how to read bytes from the given entity.
- InputEntity.CleanableFile - Interface in org.apache.druid.data.input
-
CleanableFile is the result type of
InputEntity.fetch(java.io.File, byte[])
. - InputEntityIteratingReader - Class in org.apache.druid.data.input.impl
-
InputSourceReader iterating multiple
InputEntity
s. - InputEntityIteratingReader(InputRowSchema, InputFormat, CloseableIterator<? extends InputEntity>, SystemFieldDecoratorFactory, File) - Constructor for class org.apache.druid.data.input.impl.InputEntityIteratingReader
- InputEntityReader - Interface in org.apache.druid.data.input
-
InputEntityReader knows how to parse data into
InputRow
. - InputFileAttribute - Class in org.apache.druid.data.input
-
A class storing some attributes of an input file.
- InputFileAttribute(long) - Constructor for class org.apache.druid.data.input.InputFileAttribute
- InputFileAttribute(long, long) - Constructor for class org.apache.druid.data.input.InputFileAttribute
- InputFormat - Interface in org.apache.druid.data.input
-
InputFormat abstracts the file format of input data.
- InputRow - Interface in org.apache.druid.data.input
-
An InputRow is the interface definition of an event being input into the data ingestion layer.
- InputRowHolder() - Constructor for class org.apache.druid.segment.incremental.IncrementalIndex.InputRowHolder
- InputRowListPlusRawValues - Class in org.apache.druid.data.input
- InputRowParser<T> - Interface in org.apache.druid.data.input.impl
-
Deprecated.
- InputRowSchema - Class in org.apache.druid.data.input
-
Schema of
InputRow
. - InputRowSchema(TimestampSpec, DimensionsSpec, ColumnsFilter) - Constructor for class org.apache.druid.data.input.InputRowSchema
- InputRowSchema(TimestampSpec, DimensionsSpec, ColumnsFilter, Set<String>) - Constructor for class org.apache.druid.data.input.InputRowSchema
- 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.
- InputSource - Interface in org.apache.druid.data.input
-
InputSource abstracts the storage system where input data is stored.
- InputSourceFactory - Interface in org.apache.druid.data.input
-
An interface to generate a
SplittableInputSource
objects on the fly. - InputSourceReader - Interface in org.apache.druid.data.input
- InputSplit<T> - Class in org.apache.druid.data.input
-
Input unit for distributed batch ingestion.
- InputSplit(T) - Constructor for class org.apache.druid.data.input.InputSplit
- InputStats - Interface in org.apache.druid.data.input
-
Tracks bytes read from an input source.
- InputStreamFullResponseHandler - Class in org.apache.druid.java.util.http.client.response
-
This is a clone of
InputStreamResponseHandler
except that it retains HTTP status/response object in the response holder result. - InputStreamFullResponseHandler() - Constructor for class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHandler
- InputStreamFullResponseHolder - Class in org.apache.druid.java.util.http.client.response
- InputStreamFullResponseHolder(HttpResponse) - Constructor for class org.apache.druid.java.util.http.client.response.InputStreamFullResponseHolder
- InputStreamResponseHandler - Class in org.apache.druid.java.util.http.client.response
- InputStreamResponseHandler() - Constructor for class org.apache.druid.java.util.http.client.response.InputStreamResponseHandler
- inputSupplier(ExpressionType, Supplier<T>) - Static method in class org.apache.druid.math.expr.InputBindings
- 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
- insert(String, DateTime, String, EntryType, boolean, StatusType, String, String) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Creates a new entry.
- insertOrUpdate(String, String, String, String, byte[]) - Method in interface org.apache.druid.metadata.MetadataStorageConnector
- inspectorForColumn(String, ExpressionType) - Static method in class org.apache.druid.math.expr.InputBindings
- inspectorFromTypeMap(Map<String, ExpressionType>) - Static method in class org.apache.druid.math.expr.InputBindings
-
Create an
Expr.InputBindingInspector
backed by a map of binding identifiers to theirExprType
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.frame.segment.FrameFilteredOffset
- 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.firstlast.first.NumericFirstBufferAggregator
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.firstlast.last.NumericLastBufferAggregator
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- 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.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.column.StringEncodingStrategies.Utf8ToStringIndexed
- 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.ConstantMultiValueDimensionSelector
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.FixedIndexed
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.FrontCodedIndexed
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexed
- 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.serde.CombineFirstTwoEntriesIndexed
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesIndexedInts
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.serde.ReplaceFirstValueWithNullIndexed
- 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.BaseExpressionColumnValueSelector
- 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.NestedFieldVirtualColumn.FieldDimensionSelector
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- inspectRuntimeShape(RuntimeShapeInspector) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector
- 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.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- instance() - Static method in class org.apache.druid.collections.DummyBlockingPool
- instance() - Static method in class org.apache.druid.collections.DummyNonBlockingPool
- instance() - Static method in class org.apache.druid.extendedset.intset.EmptyIntIterator
- instance() - Static method in class org.apache.druid.java.util.common.Unit
- instance() - Static method in class org.apache.druid.java.util.metrics.JvmPidDiscoverer
- instance() - Static method in class org.apache.druid.java.util.metrics.SigarPidDiscoverer
- 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.context.ResponseContext.Keys
-
Returns the single, global key registry for this server.
- 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
-
Should be used only in tests, directly or indirectly (via
GroupByQueryQueryToolChest(org.apache.druid.query.groupby.GroupingEngine, com.google.common.base.Supplier<org.apache.druid.query.groupby.GroupByQueryConfig>, org.apache.druid.query.groupby.GroupByQueryMetricsFactory, org.apache.druid.query.groupby.GroupByResourcesReservationPool)
). - instance() - Static method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
- instance() - Static method in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
- instance() - Static method in class org.apache.druid.query.search.DefaultSearchQueryMetricsFactory
- instance() - Static method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetricsFactory
-
Should be used only in tests, directly or indirectly (via
TimeseriesQueryQueryToolChest(org.apache.druid.query.timeseries.TimeseriesQueryMetricsFactory)
). - instance() - Static method in class org.apache.druid.query.topn.DefaultTopNQueryMetricsFactory
-
Should be used only in tests, directly or indirectly (via
TopNQueryQueryToolChest(org.apache.druid.query.topn.TopNQueryConfig, org.apache.druid.query.topn.TopNQueryMetricsFactory)
). - 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
- instance() - Static method in class org.apache.druid.timeline.partition.LinearPartialShardSpec
- instance() - Static method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- instance() - Static method in class org.apache.druid.timeline.partition.NumberedPartialShardSpec
- instance(Injector) - Static method in class org.apache.druid.guice.ExtensionsLoader
- INSTANCE - Static variable in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
- INSTANCE - Static variable in class org.apache.druid.common.exception.NoErrorResponseTransformStrategy
- INSTANCE - Static variable in class org.apache.druid.data.input.FilePerSplitHintSpec
- INSTANCE - Static variable in class org.apache.druid.frame.channel.ReadableNilFrameChannel
- INSTANCE - Static variable in class org.apache.druid.jackson.DefaultObjectMapper
- INSTANCE - Static variable in class org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- INSTANCE - Static variable in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder.Serializer
- INSTANCE - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
One and only global list of keys.
- INSTANCE - Static variable in class org.apache.druid.query.DirectQueryProcessingPool
- INSTANCE - Static variable in class org.apache.druid.query.filter.NullFilter.NullPredicateFactory
- INSTANCE - Static variable in class org.apache.druid.query.groupby.epinephelinae.vector.NilGroupByVectorColumnSelector
- INSTANCE - Static variable in class org.apache.druid.query.groupby.orderby.NoopLimitSpec
- INSTANCE - Static variable in class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
- INSTANCE - Static variable in class org.apache.druid.segment.join.NoopJoinableFactory
- INSTANCE - Static variable in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- INSTANCE - Static variable in class org.apache.druid.segment.serde.cell.NativeClearedByteBufferProvider
- INSTANCE - Static variable in class org.apache.druid.timeline.partition.TombstoneShardSpec
- INT_TYPE_STRATEGY - Static variable in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- IntArrayColumn - Class in org.apache.druid.query.rowsandcols.column
- IntArrayColumn(int[]) - Constructor for class org.apache.druid.query.rowsandcols.column.IntArrayColumn
- IntArrayUtils - Class in org.apache.druid.common.utils
- integerMathFunction(ExpressionType, ExpressionType) - Static method in class org.apache.druid.math.expr.ExpressionTypeConversion
-
Given 2 'input' types, choose the most appropriate combined type, if possible arrays must be the same type if either type is
ExprType.STRING
, the output type will be preserved as string any number will be coerced toExprType.LONG
- IntegerPartitionChunk<T extends Overshadowable> - Class in org.apache.druid.timeline.partition
- IntegerPartitionChunk(Integer, Integer, int, T) - Constructor for class org.apache.druid.timeline.partition.IntegerPartitionChunk
- 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
- intermediateRowAsString(byte[]) - Method in class org.apache.druid.data.input.TextReader.Bytes
- intermediateRowAsString(InputEntity) - Method in class org.apache.druid.data.input.impl.JsonReader
- intermediateRowAsString(T) - Method in class org.apache.druid.data.input.IntermediateRowParsingReader
-
String representation of an intermediate row.
- intermediateRowIterator() - Method in class org.apache.druid.data.input.impl.JsonNodeReader
- intermediateRowIterator() - Method in class org.apache.druid.data.input.impl.JsonReader
- intermediateRowIterator() - Method in class org.apache.druid.data.input.IntermediateRowParsingReader
-
Creates an iterator of intermediate rows.
- intermediateRowIteratorWithMetadata() - Method in class org.apache.druid.data.input.IntermediateRowParsingReader
-
Same as
intermediateRowIterator
, but it also contains the metadata such as the line number to generate more informativeParseException
. - intermediateRowIteratorWithMetadata() - Method in class org.apache.druid.data.input.TextReader
- IntermediateRowParsingReader<T> - Class in org.apache.druid.data.input
-
InputEntityReader
that parses bytes into some intermediate rows first, and then intoInputRow
s. - IntermediateRowParsingReader() - Constructor for class org.apache.druid.data.input.IntermediateRowParsingReader
- intermediateValueWriter - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- intermediateValueWriter - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- InternalServerError - Class in org.apache.druid.error
- internalToString() - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- internalToString() - Method in class org.apache.druid.query.operator.window.value.WindowValueProcessorBase
- intersect(Set<T>, Set<T>) - Static method in class org.apache.druid.utils.CollectionUtils
-
Intersection of two sets:
C = A ∩ B
. - 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(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.collections.bitmap.RoaringBitmapFactory
- intersection(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
- intersection(Iterable<ImmutableConciseSet>) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- 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(Iterator<ImmutableConciseSet>) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- intersection(ImmutableBitmap) - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
-
Compute the bitwise-and of this bitmap with another bitmap.
- 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(ImmutableConciseSet...) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- intersection(IntSet) - Method in class org.apache.druid.extendedset.intset.ConciseSet
- interval - Variable in class org.apache.druid.query.search.CursorOnlyStrategy.CursorBasedExecutor
- interval - Variable in class org.apache.druid.query.search.SearchStrategy
- interval(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- interval(Interval) - Method in class org.apache.druid.timeline.DataSegment.Builder
- interval(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
- interval(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
-
Sets
Query.getIntervals()
of the given query as dimension. - INTERVAL - org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
- INTERVAL - Static variable in class org.apache.druid.query.DruidMetrics
- IntervalDimFilter - Class in org.apache.druid.query.filter
- IntervalDimFilter(String, List<Interval>, ExtractionFn) - Constructor for class org.apache.druid.query.filter.IntervalDimFilter
- IntervalDimFilter(String, List<Interval>, ExtractionFn, FilterTuning) - Constructor for class org.apache.druid.query.filter.IntervalDimFilter
- intervals() - Static method in class org.apache.druid.java.util.common.guava.Comparators
-
Deprecated.
- intervals(String) - Method in class org.apache.druid.query.Druids.DataSourceMetadataQueryBuilder
- intervals(String) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- intervals(String) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- intervals(String) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
- intervals(String) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- intervals(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- intervals(List<Interval>) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- intervals(List<Interval>) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- intervals(List<Interval>) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- intervals(List<Interval>) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- intervals(QuerySegmentSpec) - 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(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.TimeBoundaryQueryBuilder
- intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- intervals(QuerySegmentSpec) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- Intervals - Class in org.apache.druid.java.util.common
- intervalsByEndThenStart() - Static method in class org.apache.druid.java.util.common.guava.Comparators
- IntervalsByGranularity - Class in org.apache.druid.java.util.common.granularity
-
Produce a stream of intervals generated by a given set of intervals as input and a given granularity.
- IntervalsByGranularity(Collection<Interval>, Granularity) - Constructor for class org.apache.druid.java.util.common.granularity.IntervalsByGranularity
- intervalsByStartThenEnd() - Static method in class org.apache.druid.java.util.common.guava.Comparators
- intervalValidation(WindowRankingProcessorBase) - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- intervalValidation(WindowValueProcessorBase) - Method in class org.apache.druid.query.operator.window.value.WindowValueProcessorBase
- 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
- IntIndexView - Class in org.apache.druid.segment.serde.cell
- IntIndexView(ByteBuffer) - Constructor for class org.apache.druid.segment.serde.cell.IntIndexView
- IntIndexView.EntrySpan - Class in org.apache.druid.segment.serde.cell
- IntIteratorUtils - Class in org.apache.druid.segment
- IntKey - Class in org.apache.druid.query.groupby.epinephelinae
- IntKey(int) - Constructor for class org.apache.druid.query.groupby.epinephelinae.IntKey
- IntList - Class in org.apache.druid.extendedset.utilities
- IntList() - Constructor for class org.apache.druid.extendedset.utilities.IntList
- IntListUtils - Class in org.apache.druid.segment
- IntSerializer - Class in org.apache.druid.segment.serde.cell
- IntSerializer() - Constructor for class org.apache.druid.segment.serde.cell.IntSerializer
- IntSet - Interface in org.apache.druid.extendedset.intset
- IntSet.IntIterator - Interface in org.apache.druid.extendedset.intset
-
An
Iterator
-like interface that allows to "skip" some elements of the set - intValue() - Method in class org.apache.druid.query.groupby.epinephelinae.IntKey
- INVALID_INPUT - org.apache.druid.error.DruidException.Category
-
Means that the input provided was malformed in some way.
- INVALID_ROW - Static variable in interface org.apache.druid.segment.IndexMerger
- invalidCast(ExpressionType, ExpressionType) - Static method in class org.apache.druid.math.expr.ExprEval
- InvalidCastBooleanException(TypeSignature<?>) - Constructor for exception org.apache.druid.segment.column.Types.InvalidCastBooleanException
- InvalidCastException(TypeSignature<?>, TypeSignature<?>) - Constructor for exception org.apache.druid.segment.column.Types.InvalidCastException
- InvalidFieldException - Exception in org.apache.druid.frame.write
- InvalidFieldException.Builder - Class in org.apache.druid.frame.write
- InvalidInput - Class in org.apache.druid.error
-
A failure type used to make
DruidException
s of categoryDruidException.Category.INVALID_INPUT
for personaDruidException.Persona.USER
. - InvalidInput(Throwable, String, Object...) - Constructor for class org.apache.druid.error.InvalidInput
- InvalidNullByteException - Exception in org.apache.druid.frame.write
-
Exception thrown by
FrameWriterUtils.copyByteBufferToMemory(java.nio.ByteBuffer, org.apache.datasketches.memory.WritableMemory, long, int, boolean)
if configured to check for null bytes and a null byte is encountered. - InvalidNullByteException.Builder - Class in org.apache.druid.frame.write
- InvalidSqlInput - Class in org.apache.druid.error
- InvalidSqlInput(Throwable, String, Object...) - Constructor for class org.apache.druid.error.InvalidSqlInput
- inverse(int[]) - Static method in class org.apache.druid.common.utils.IntArrayUtils
-
Inverses the values of the given array with their indexes.
- invertedOrderForLastK(int, int, int) - Static method in class org.apache.druid.query.rowsandcols.semantic.DefaultFramedOnHeapAggregatable
-
Inverts order for the last K elements.
- InvertedTopNMetricSpec - Class in org.apache.druid.query.topn
- InvertedTopNMetricSpec(TopNMetricSpec) - Constructor for class org.apache.druid.query.topn.InvertedTopNMetricSpec
- IOE - Exception in org.apache.druid.java.util.common
- IOE(String, Object...) - Constructor for exception org.apache.druid.java.util.common.IOE
- IOE(Throwable, String, Object...) - Constructor for exception org.apache.druid.java.util.common.IOE
- IOIterator<T> - Interface in org.apache.druid.segment.serde.cell
- IPv4AddressExprUtils - Class in org.apache.druid.query.expression
- IPv4AddressExprUtils() - Constructor for class org.apache.druid.query.expression.IPv4AddressExprUtils
- 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
- IPv6AddressExprUtils - Class in org.apache.druid.query.expression
- IPv6AddressExprUtils() - Constructor for class org.apache.druid.query.expression.IPv6AddressExprUtils
- IPv6AddressMatchExprMacro - Class in org.apache.druid.query.expression
-
Implements an expression that checks if an IPv6 address belongs to a subnet.
- IPv6AddressMatchExprMacro() - Constructor for class org.apache.druid.query.expression.IPv6AddressMatchExprMacro
- is(TypeSignature<T>, T) - Static method in class org.apache.druid.segment.column.Types
-
Returns true if
TypeSignature.getType()
is of the specifiedTypeDescriptor
- is(ExpressionPlan.Trait...) - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
Returns true if all of the supplied traits are true in this plan
- is(Type) - Method in interface org.apache.druid.segment.column.TypeSignature
-
Check if the value of
TypeSignature.getType()
is equal to the candidateTypeDescriptor
. - IS_COMPACTED - Static variable in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- IS_EXCEPTION - Static variable in class org.apache.druid.java.util.common.FileUtils
-
Useful for retry functionality that doesn't want to stop Throwables, but does want to retry on Exceptions
- IS_FINER_THAN - Static variable in class org.apache.druid.java.util.common.granularity.Granularity
- IS_NOT_NULL_BYTE - Static variable in class org.apache.druid.common.config.NullHandling
- IS_NULL_BYTE - Static variable in class org.apache.druid.common.config.NullHandling
- IS_SORTED_MASK - Static variable in class org.apache.druid.segment.data.FixedIndexed
- isAggregateAllMetrics() - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
- isAggregateMultipleValues() - Method in class org.apache.druid.query.aggregation.any.StringAnyVectorAggregator
- isAggregateTopNMetricFirst() - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
- isAligned(Interval) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
-
No interval is aligned with all granularity since it's infinite.
- isAligned(Interval) - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- isAligned(Interval) - Method in class org.apache.druid.java.util.common.granularity.Granularity
-
Return true only if the time chunks populated by this granularity includes the given interval time chunk.
- isAligned(Interval) - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
-
Any interval is aligned with none granularity since it's effectively millisecond granularity.
- isAligned(Interval) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- isAllConstants(List<Expr>) - Static method in class org.apache.druid.math.expr.Evals
- isAllConstants(Expr...) - Static method in class org.apache.druid.math.expr.Evals
- 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
- isAllOnesLiteral(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- isAllowList() - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- 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
- isAllUnique() - Method in class org.apache.druid.segment.join.Joinable.ColumnValuesWithUniqueFlag
- isAllZerosLiteral(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- 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
- isArray() - Method in class org.apache.druid.math.expr.ExprEval
- isArray() - Method in enum org.apache.druid.math.expr.ExprType
- isArray() - Method in interface org.apache.druid.segment.column.TypeDescriptor
-
Value is an array of some other
TypeDescriptor
- isArray() - Method in interface org.apache.druid.segment.column.TypeSignature
-
Check if the type is an array (
TypeDescriptor.isArray()
) - isArray() - Method in enum org.apache.druid.segment.column.ValueType
-
Type is an array type
- isArray(ValueType) - Static method in enum org.apache.druid.segment.column.ValueType
- isAsMillis() - Method in class org.apache.druid.query.extraction.TimeFormatExtractionFn
- isAsPercent() - Method in class org.apache.druid.query.operator.window.ranking.WindowRankProcessor
- isAssumeGrouped() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- isAssumeNewlineDelimited() - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- isAwait() - Method in class org.apache.druid.frame.processor.ReturnOrAwait
-
Whether the processor wants to be scheduled again.
- isAwaitAll() - Method in class org.apache.druid.frame.processor.ReturnOrAwait
-
Whether the processor wants to wait for all channels in
ReturnOrAwait.awaitSet()
(true), or any channel (false) - isBaseColumn(String) - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
Returns whether "column" on the analyzed datasource refers to a column from the base datasource.
- isBaseColumn(String) - Method in class org.apache.druid.segment.join.HashJoinSegmentStorageAdapter
-
Returns whether "column" will be selected from "baseAdapter".
- IsBooleanDimFilter - Class in org.apache.druid.query.filter
-
Abstract SQL three-value logic wrapper for some child
DimFilter
to implement '{filter} IS TRUE' and '{filter} IS FALSE'. - IsBooleanDimFilter(DimFilter, boolean) - Constructor for class org.apache.druid.query.filter.IsBooleanDimFilter
- IsBooleanFilter - Class in org.apache.druid.segment.filter
-
SQL three-value logic wrapper for some child
Filter
to implement '{filter} IS TRUE' and '{filter} IS FALSE'. - IsBooleanFilter(Filter, boolean) - Constructor for class org.apache.druid.segment.filter.IsBooleanFilter
- isBucketUsed(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- isByRow() - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
- isBySegment() - Method in class org.apache.druid.query.QueryContext
- isBySegment(boolean) - Method in class org.apache.druid.query.QueryContext
- isByteComparable() - Method in class org.apache.druid.frame.key.RunLengthEntry
- isByteOrderCompatible(ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableBase
- isCacheable() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
- isCacheable() - Method in class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- isCacheable() - Method in interface org.apache.druid.segment.join.table.IndexedTable
-
Returns whether this indexed table can be cached for the join operations
- isCacheable() - Method in class org.apache.druid.segment.join.table.ReferenceCountingIndexedTable
- isCacheable() - Method in class org.apache.druid.segment.join.table.RowBasedIndexedTable
- isCacheable(boolean) - 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 class org.apache.druid.query.FilteredDataSource
- isCacheable(boolean) - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- isCacheable(boolean) - Method in class org.apache.druid.query.GlobalTableDataSource
-
Query results from Broadcast datasources should not be cached on broker https://github.com/apache/druid/issues/10444
- isCacheable(boolean) - Method in class org.apache.druid.query.InlineDataSource
- isCacheable(boolean) - Method in class org.apache.druid.query.JoinDataSource
- isCacheable(boolean) - Method in class org.apache.druid.query.LookupDataSource
- isCacheable(boolean) - Method in class org.apache.druid.query.QueryDataSource
- isCacheable(boolean) - Method in class org.apache.druid.query.TableDataSource
- isCacheable(boolean) - Method in class org.apache.druid.query.UnionDataSource
- isCacheable(boolean) - Method in class org.apache.druid.query.UnnestDataSource
- isCacheable(QueryType, boolean) - Method in interface org.apache.druid.query.CacheStrategy
-
Deprecated.
- isCacheable(QueryType, boolean, boolean) - Method in interface org.apache.druid.query.CacheStrategy
-
Returns whether the given query is cacheable or not.
- 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.frame.channel.ComposingWritableFrameChannel
- isClosed() - Method in interface org.apache.druid.frame.channel.WritableFrameChannel
-
Whether
WritableFrameChannel.close()
has been called on this channel. - isClosed() - Method in class org.apache.druid.frame.channel.WritableFrameFileChannel
- isClosed() - Method in class org.apache.druid.segment.ReferenceCountingCloseableObject
- isComplete() - Method in enum org.apache.druid.indexer.TaskState
- isComplete() - Method in class org.apache.druid.indexer.TaskStatus
-
Inverse of
TaskStatus.isRunnable()
. - isComplete() - Method in class org.apache.druid.timeline.partition.PartitionHolder
- isConcrete() - Method in interface org.apache.druid.query.DataSource
-
Returns true if this datasource can be the base datasource of query processing.
- isConcrete() - Method in class org.apache.druid.query.FilteredDataSource
- isConcrete() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- 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
- isConcrete() - Method in class org.apache.druid.query.UnnestDataSource
- isConcreteAndTableBased() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
Returns true if this datasource is both (see
DataSourceAnalysis.isConcreteBased()
andDataSourceAnalysis.isTableBased()
. - 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.
- isConstant - Variable in class org.apache.druid.segment.AutoTypeColumnIndexer
- isConstant() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- isConstant() - Method in class org.apache.druid.segment.IndexableAdapter.NestedColumnMergable
- isConstant() - Method in class org.apache.druid.segment.virtual.ExpressionPlan
-
An expression with no inputs is a constant
- 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.
- isContinueReading() - Method in class org.apache.druid.java.util.http.client.response.ClientResponse
- isCreateTables() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- isDebug() - Method in class org.apache.druid.query.QueryContext
- isDebugEnabled() - Method in class org.apache.druid.java.util.common.logger.Logger
- 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
- isDimensionOrderingValid(List<IndexableAdapter>, Iterable<String>) - Static method in interface org.apache.druid.segment.IndexMerger
- isDirect() - Method in class org.apache.druid.segment.data.SafeWritableBase
- isDirectlyJoinable(DataSource) - Method in class org.apache.druid.segment.join.FrameBasedInlineJoinableFactory
- isDirectlyJoinable(DataSource) - Method in class org.apache.druid.segment.join.InlineJoinableFactory
- isDirectlyJoinable(DataSource) - Method in interface org.apache.druid.segment.join.JoinableFactory
-
Returns true if a
Joinable
**may** be created for a givenDataSource
, but is not a guarantee thatJoinableFactory.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
- isDirectlyJoinable(DataSource) - Method in class org.apache.druid.segment.join.NoopJoinableFactory
- 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.
- IsDistinctFromFunc() - Constructor for class org.apache.druid.math.expr.Function.IsDistinctFromFunc
- isDone() - Method in class org.apache.druid.frame.segment.columnar.FrameVectorCursor
- isDone() - Method in class org.apache.druid.frame.segment.FrameCursor
- isDone() - Method in class org.apache.druid.java.util.common.guava.ExecuteWhenDoneYielder
- isDone() - Method in interface org.apache.druid.java.util.common.guava.Yielder
-
Returns true if this is the last Yielder in the chain.
- 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.UnnestColumnValueSelectorCursor
- isDone() - Method in class org.apache.druid.segment.UnnestDimensionCursor
- 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 class org.apache.druid.frame.segment.FrameCursor
- 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
- isDoneOrInterrupted() - Method in class org.apache.druid.segment.UnnestColumnValueSelectorCursor
- isDoneOrInterrupted() - Method in class org.apache.druid.segment.UnnestDimensionCursor
- ISE - Exception in org.apache.druid.java.util.common
- ISE(String, Object...) - Constructor for exception org.apache.druid.java.util.common.ISE
- ISE(Throwable, String, Object...) - Constructor for exception org.apache.druid.java.util.common.ISE
- isEagerInitialization() - Method in class org.apache.druid.java.util.http.client.HttpClientConfig
- isEffectivelyNull(Integer) - Static method in interface org.apache.druid.indexer.partitions.PartitionsSpec
-
'-1' regarded as null for some historical reason.
- isEffectivelyNull(Long) - Static method in interface org.apache.druid.indexer.partitions.PartitionsSpec
-
'-1' regarded as null for some historical reason.
- 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() - Method in class org.apache.druid.collections.RangeIntSet
- isEmpty() - Method in class org.apache.druid.extendedset.intset.AbstractIntSet
- isEmpty() - Method in class org.apache.druid.extendedset.intset.ConciseSet
- isEmpty() - Method in interface org.apache.druid.extendedset.intset.IntSet
- isEmpty() - Method in class org.apache.druid.extendedset.utilities.IntList
- isEmpty() - Method in class org.apache.druid.frame.key.ClusterBy
-
Whether this key is empty.
- isEmpty() - Method in class org.apache.druid.query.QueryContext
- isEmpty() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- isEmpty() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- isEmpty() - Method in class org.apache.druid.segment.VirtualColumns
- isEmpty() - Method in class org.apache.druid.timeline.partition.PartitionHolder
- isEmpty() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- isEmpty(ImmutableBitmap) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
- isEmpty(Interval) - Static method in class org.apache.druid.java.util.common.Intervals
- isEmpty(T) - Method in interface org.apache.druid.query.BitmapResultFactory
-
Checks that the wrapped bitmap is empty, see
ImmutableBitmap.isEmpty()
. - isEnableCompareAndSwap() - Method in class org.apache.druid.common.config.ConfigManagerConfig
- isEnabled() - Method in class org.apache.druid.js.JavaScriptConfig
- 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
- isEnableRewriteJoinToFilter() - Method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
- isEnableRewriteValueColumnFilters() - Method in class org.apache.druid.segment.join.filter.rewrite.JoinFilterRewriteConfig
- isEnd() - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- isEnd() - Method in class org.apache.druid.timeline.partition.LinearPartitionChunk
- isEnd() - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- isEnd() - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- isEnd() - Method in interface org.apache.druid.timeline.partition.PartitionChunk
-
Returns true if this chunk is the end of the partition.
- isEnd() - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- isEnd() - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- isEnd() - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- isEquality() - Method in class org.apache.druid.query.filter.RangeFilter
- isError() - Method in class org.apache.druid.java.util.common.Either
- isError() - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis
- isErrorOrFinished() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
- isEternity(Interval) - Static method in class org.apache.druid.java.util.common.Intervals
-
Returns true if the provided interval contains all time.
- isExact() - Method in interface org.apache.druid.segment.column.ColumnIndexCapabilities
-
Indicates if an index is an exact match, or should also be post-filtered with a value matcher.
- isExact() - Method in class org.apache.druid.segment.column.SimpleColumnIndexCapabilities
- isExceptionCaught() - Method in class org.apache.druid.frame.file.FrameFilePartialFetch
-
Whether an exception was encountered during response processing.
- isFailure() - Method in enum org.apache.druid.indexer.TaskState
- isFailure() - Method in class org.apache.druid.indexer.TaskStatus
-
Returned by tasks when they complete unsuccessfully.
- isFalse() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- IsFalseDimFilter - Class in org.apache.druid.query.filter
- IsFalseDimFilter(DimFilter) - Constructor for class org.apache.druid.query.filter.IsFalseDimFilter
- IsFalseFunc() - Constructor for class org.apache.druid.math.expr.Function.IsFalseFunc
- isFifo() - Method in class org.apache.druid.query.DruidProcessingConfig
- isFinalize() - Method in class org.apache.druid.query.groupby.having.DimFilterHavingSpec
- isFinalize(boolean) - Method in class org.apache.druid.query.QueryContext
- isFindColumnsFromHeader() - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
- isFinerThan(Granularity) - Method in class org.apache.druid.java.util.common.granularity.Granularity
-
Decides whether this granularity is finer than the other granularity
- isFinished() - Method in class org.apache.druid.frame.channel.ComposingReadableFrameChannel
- isFinished() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
- isFinished() - Method in class org.apache.druid.frame.channel.ReadableConcatFrameChannel
- isFinished() - Method in class org.apache.druid.frame.channel.ReadableFileFrameChannel
- isFinished() - Method in interface org.apache.druid.frame.channel.ReadableFrameChannel
-
Returns whether this channel is finished.
- isFinished() - Method in class org.apache.druid.frame.channel.ReadableInputStreamFrameChannel
- isFinished() - Method in class org.apache.druid.frame.channel.ReadableNilFrameChannel
- isFinished() - Method in class org.apache.druid.java.util.http.client.response.ClientResponse
- isForceGuaranteedRollupCompatible() - Method in interface org.apache.druid.indexer.partitions.PartitionsSpec
- isForceGuaranteedRollupCompatibleType() - Method in interface org.apache.druid.indexer.partitions.PartitionsSpec
- isForceHashAggregation() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- isForceNestedType() - Method in class org.apache.druid.segment.IndexableAdapter.NestedColumnMergable
- isForcePushDownLimit() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- isForcePushDownNestedQuery() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- isFromPartiallyValidRow() - Method in exception org.apache.druid.java.util.common.parsers.ParseException
- isFromTombstone() - Method in interface org.apache.druid.segment.StorageAdapter
- 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.FilteredDataSource
- isGlobal() - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- 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.QueryDataSource
- isGlobal() - Method in class org.apache.druid.query.TableDataSource
- isGlobal() - Method in class org.apache.druid.query.UnionDataSource
- isGlobal() - Method in class org.apache.druid.query.UnnestDataSource
- isGood(ChannelFuture) - Method in class org.apache.druid.java.util.http.client.pool.ChannelResourceFactory
- isGood(V) - Method in interface org.apache.druid.java.util.http.client.pool.ResourceFactory
- isGrandTotal() - Method in class org.apache.druid.query.timeseries.TimeseriesQuery
- isGz(String) - Static method in class org.apache.druid.utils.CompressionUtils
-
Checks to see if fName is a valid name for a "*.gz" file
- isHasExtractionFn() - Method in class org.apache.druid.query.topn.TopNAlgorithmSelector
- isHasHeaderRow() - Method in class org.apache.druid.data.input.impl.CSVParseSpec
- isHasHeaderRow() - Method in class org.apache.druid.data.input.impl.DelimitedParseSpec
- 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
- isHasNulls() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- isHomogenizeNullMultiValueStringArrays() - Static method in class org.apache.druid.math.expr.ExpressionProcessing
-
All multi-value string expression input values of 'null', '[]', and '[null]' will be coerced to '[null]'.
- isHomogenizeNullMultiValueStringArrays() - Method in class org.apache.druid.math.expr.ExpressionProcessingConfig
- isIdentifier() - Method in interface org.apache.druid.math.expr.Expr
- isIgnoreNullsForStringCardinality() - Method in class org.apache.druid.common.config.NullValueHandlingConfig
- isIncludeAllDimensions() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- isIncludeNull() - Method in class org.apache.druid.segment.join.Equality
-
Whether null is treated as a value that can be equal to itself.
- isInfoEnabled() - Method in class org.apache.druid.java.util.common.logger.Logger
- 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
- isInitialized() - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
- 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
- isIntermediateResultAsMapCompat() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- isInvertible() - Method in interface org.apache.druid.segment.column.ColumnIndexCapabilities
-
Indicates if an index can be inverted for use with a 'NOT' filter.
- isInvertible() - Method in class org.apache.druid.segment.column.SimpleColumnIndexCapabilities
- isIsJava9Compatible() - Static method in class org.apache.druid.utils.JvmUtils
- isJoda() - Method in class org.apache.druid.query.extraction.TimeDimExtractionFn
- isJoin() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
Returns true if this datasource is made out of a join operation
- isKeepNullColumns() - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- isLastFetch() - Method in class org.apache.druid.frame.file.FrameFilePartialFetch
- isLeaf() - Method in class org.apache.druid.collections.spatial.ImmutableFloatNode
- isLeaf() - Method in interface 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
- isLefty() - Method in enum org.apache.druid.segment.join.JoinType
-
"Lefty" joins (LEFT or FULL) always include the full left-hand side, and can generate nulls on the right.
- 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
- 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.
- isLiteral() - Method in interface org.apache.druid.math.expr.Expr
-
Indicates expression is a constant whose literal value can be extracted by
Expr.getLiteralValue()
, making evaluating with arguments and bindings unecessary - isLiteral(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Checks whether a word is a literal one
- isLiteralWithSingleOneBit(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- isLiteralWithSingleZeroBit(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- isLowerOpen() - Method in class org.apache.druid.query.filter.RangeFilter
- isLowerStrict() - Method in class org.apache.druid.query.filter.BoundDimFilter
- isLowerUnbounded() - Method in class org.apache.druid.query.operator.window.WindowFrame
- isMap(Object) - Method in class org.apache.druid.data.input.impl.FastJacksonJsonNodeJsonProvider
- isMaybeTrue() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- isMerge() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- isMergeThreadLocal() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- isMetric() - Method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- isMultiValueUnnestingEnabled() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- isNaturalComparator(ValueType, StringComparator) - Static method in class org.apache.druid.query.DimensionComparisonUtils
-
Checks if the comparator is the natural comparator for the given type.
- isNestedQueryPushDown(GroupByQuery) - Static method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- isNil() - Method in class org.apache.druid.metadata.TaskLookup.ActiveTaskLookup
- isNil() - Method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- isNil() - Method in interface org.apache.druid.metadata.TaskLookup
-
Whether this lookup is guaranteed to not return any tasks.
- isNilSelector(DimensionSelector) - Static method in interface org.apache.druid.segment.DimensionSelector
-
Checks if the given selector constantly returns null.
- isNonEmpty() - Method in class org.apache.druid.segment.SegmentSchemaMapping
- IsNotDistinctFromFunc() - Constructor for class org.apache.druid.math.expr.Function.IsNotDistinctFromFunc
- IsNotFalseFunc() - Constructor for class org.apache.druid.math.expr.Function.IsNotFalseFunc
- isNotNull(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Creates an
ExprVectorProcessor
for the 'isnotnull' function, that produces a "boolean" typed output vector (long[]) with values set to 1 if the input value was not null or 0 if it was null. - IsNotNullFunc() - Constructor for class org.apache.druid.math.expr.Function.IsNotNullFunc
- IsNotTrueFunc() - Constructor for class org.apache.druid.math.expr.Function.IsNotTrueFunc
- isNull() - Method in class org.apache.druid.frame.field.NumericArrayFieldSelector
- 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() - Method in class org.apache.druid.query.aggregation.DelegatingAggregator
- isNull() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregator
- isNull() - Method in class org.apache.druid.query.aggregation.FilteredAggregator
- isNull() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
- isNull() - Method in class org.apache.druid.query.aggregation.NullableNumericAggregator
- isNull() - Method in class org.apache.druid.query.aggregation.SingleValueAggregator
- isNull() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedAggregator
- isNull() - Static method in interface org.apache.druid.query.filter.DruidObjectPredicate
- 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() - Method in class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
- 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.ObjectBasedColumnSelector
- isNull() - Method in class org.apache.druid.segment.ObjectColumnSelector
- 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.BaseExpressionColumnValueSelector
- isNull() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- isNull() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector
- isNull() - Method in class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
- isNull(int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- isNull(int) - Method in class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- isNull(int) - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Get whether the value of a row is null
- isNull(int) - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- isNull(int) - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix.MatrixRow
- isNull(int, int) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- isNull(int, int) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
- 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(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.DelegatingBufferAggregator
- isNull(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.FilteredBufferAggregator
- isNull(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.NullableNumericBufferAggregator
- isNull(ByteBuffer, int) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory.SuppressedBufferAggregator
- isNull(Memory, long) - Method in class org.apache.druid.frame.field.ComplexFieldReader
- isNull(Memory, long) - Method in interface org.apache.druid.frame.field.FieldReader
-
Whether the provided memory position points to a null value.
- isNull(Memory, long) - Method in class org.apache.druid.frame.field.NumericArrayFieldReader
- isNull(Memory, long) - Method in class org.apache.druid.frame.field.NumericFieldReader
- isNull(Memory, long) - Method in class org.apache.druid.frame.field.StringFieldReader
- isNull(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Creates an
ExprVectorProcessor
for the 'isnull' function, that produces a "boolean" typed output vector (long[]) with values set to 1 if the input value was null or 0 if it was not null. - isNullableNull(ByteBuffer, int) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Checks if a 'nullable' value's null byte is set to
NullHandling.IS_NULL_BYTE
. - IsNullFunc() - Constructor for class org.apache.druid.math.expr.Function.IsNullFunc
- isNullLiteral() - Method in interface org.apache.druid.math.expr.Expr
- isNullOr(TypeSignature<T>, T) - Static method in class org.apache.druid.segment.column.Types
-
Returns true if
TypeSignature.getType()
is null, or of the specifiedTypeDescriptor
- isNullOrAnyOf(TypeSignature<T>, T...) - Static method in class org.apache.druid.segment.column.Types
-
Returns true if the
TypeSignature
is null, or is any one of the specifiedTypeDescriptor
- isNullOrEmpty(Collection<?>) - Static method in class org.apache.druid.utils.CollectionUtils
- isNullOrEquivalent(String) - Static method in class org.apache.druid.common.config.NullHandling
- isNullOrEquivalent(ByteBuffer) - Static method in class org.apache.druid.common.config.NullHandling
- isNullRow(int) - Static method in class org.apache.druid.frame.read.columnar.FrameColumnReaderUtils
-
When given a return value from
FrameColumnReaderUtils.getCumulativeRowLength(Memory, long, int)
, returns whether the row is null itself (i.e. - isNullUnlessAggregated() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory.FactorizePlan
- isNumCorePartitionsUnknown() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- isNumeric() - Method in enum org.apache.druid.math.expr.ExprType
- isNumeric() - Method in interface org.apache.druid.segment.column.TypeDescriptor
-
Scalar numeric primitive values.
- isNumeric() - Method in interface org.apache.druid.segment.column.TypeSignature
-
Check if the type is numeric (
TypeDescriptor.isNumeric()
) - isNumeric() - Method in enum org.apache.druid.segment.column.ValueType
-
Type is a numeric type, not including numeric array types
- isNumeric(String) - Method in class org.apache.druid.segment.column.RowSignature
-
Returns true if the column is a numeric type (
TypeSignature.isNumeric()
), otherwise false if the column is not a numeric type or is not present in the row signature. - isNumeric(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- isNumeric(List<NestedPathPart>) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Shortcut to check if a nested field column is
TypeSignature.isNumeric()
, useful when broadly choosing the type of vector selector to be used when dealing with the path - isNumeric(TypeSignature<T>) - Static method in class org.apache.druid.segment.column.Types
-
Returns true if
TypeSignature
is not null and isTypeSignature.isNumeric()
- isNumeric(ValueType) - Static method in enum org.apache.druid.segment.column.ValueType
- isNumericNull() - Method in class org.apache.druid.math.expr.ExprEval
-
The method returns true if numeric primitive value for this
ExprEval
is null, otherwise false. - isNumericNull(Object) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- isNumericOrNumericArray(TypeSignature<T>) - Static method in class org.apache.druid.segment.column.Types
-
Returns true if
TypeSignature
is not null and isTypeSignature.isNumeric()
or hasTypeSignature.getElementType()
that is numeric. - isNumMergeBuffersConfigured() - Method in class org.apache.druid.query.DruidProcessingConfig
- isNumThreadsConfigured() - Method in class org.apache.druid.query.DruidProcessingConfig
- ISO_DATE_OPTIONAL_TIME - Static variable in class org.apache.druid.java.util.common.DateTimes
- ISO_DATE_OR_TIME_WITH_OFFSET - Static variable in class org.apache.druid.java.util.common.DateTimes
- ISO_DATE_TIME - Static variable in class org.apache.druid.java.util.common.DateTimes
- ISODOW - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- 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.common.config.ConfigManager.SetResult
- isOk() - Method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
-
True if all rows have been processed.
- isOneSequence(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Checks whether a word contains a sequence of 1's
- isOneToOne() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
- isOneToOne() - Method in class org.apache.druid.query.lookup.ImmutableLookupMap.ImmutableLookupExtractor
- isOneToOne() - Method in class org.apache.druid.query.lookup.LookupExtractor
- isOpen() - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- 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
- isOutputArray() - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Returns true if any expression in this expression tree produces array outputs as reported by
Function.hasArrayOutput()
orApplyFunction.hasArrayOutput(LambdaExpr)
- isOvershadowed() - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- isOvershadowed(DataSegment) - Method in class org.apache.druid.timeline.SegmentTimeline
- isOvershadowed(Interval, VersionType, ObjectType) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- ISOYEAR - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- isPermuted() - Method in class org.apache.druid.frame.Frame
- isPoisoned() - Static method in class org.apache.druid.collections.StupidPool
- isPopulateCache() - Method in class org.apache.druid.query.QueryContext
- isPopulateCache(boolean) - Method in class org.apache.druid.query.QueryContext
- isPopulateResultLevelCache() - Method in class org.apache.druid.query.QueryContext
- isPopulateResultLevelCache(boolean) - Method in class org.apache.druid.query.QueryContext
- isPrefix(List<T>, List<T>) - Static method in class org.apache.druid.java.util.common.collect.Utils
- isPrefixedBy(String, String) - Static method in class org.apache.druid.segment.join.JoinPrefixUtils
- isPresent() - Method in class org.apache.druid.query.operator.OffsetLimit
- isPreserveExistingMetrics() - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex.Spec
- isPrimitive() - Method in enum org.apache.druid.math.expr.ExprType
- isPrimitive() - Method in interface org.apache.druid.segment.column.TypeDescriptor
-
Scalar numeric and string values.
- isPrimitive() - Method in interface org.apache.druid.segment.column.TypeSignature
-
Check if the type is a primitive (
TypeDescriptor.isPrimitive()
, e.g. - isPrimitive() - Method in enum org.apache.druid.segment.column.ValueType
-
Type is a 'primitive' type, which includes the
ValueType.isNumeric()
types andValueType.STRING
, but notValueType.COMPLEX
orValueType.ARRAY
types. - isPrimitiveArray() - Method in interface org.apache.druid.segment.column.TypeSignature
- isProcessFromRaw() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- isQueryGranularityAllowed(Interval, Granularity) - Static method in class org.apache.druid.segment.RowBasedStorageAdapter
-
Whether the provided time interval and granularity combination is allowed.
- isQueryResultFileActive(String, Set<String>) - Static method in class org.apache.druid.frame.util.DurableStorageUtils
-
Tries to parse out the controller taskID from the query results path, and checks if the taskID is present in the set of known tasks.
- isReadableChannelReady() - Method in class org.apache.druid.frame.processor.OutputChannel
-
Whether
OutputChannel.getReadableChannel()
is ready to use. - isReadOnly() - Method in class org.apache.druid.segment.data.SafeWritableBase
- isRealtime() - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- 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
- isRetryable() - Method in class org.apache.druid.common.config.ConfigManager.SetResult
- isReturn() - Method in class org.apache.druid.frame.processor.ReturnOrAwait
-
Whether the processor has returned a value.
- isRighty() - Method in enum org.apache.druid.segment.join.JoinType
-
"Righty" joins (RIGHT or FULL) always include the full right-hand side, and can generate nulls on the left.
- 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
- isRunnable() - Method in enum org.apache.druid.indexer.TaskState
- isRunnable() - Method in class org.apache.druid.indexer.TaskStatus
-
Signals that a task is not yet complete, and is still runnable on a worker.
- isRunning() - Method in class org.apache.druid.java.util.common.Stopwatch
- isSameResource(Object) - Method in class org.apache.druid.segment.data.SafeWritableBase
- isSecondaryPartitionPruningEnabled() - Method in class org.apache.druid.query.QueryContext
- isSegmentAvailabilityConfirmed() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- isSequenceWithNoBits(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Checks whether a word contains a sequence of 0's with no set bit, or 1's with no unset bit.
- isSerializeDateTimeAsLong(boolean) - Method in class org.apache.druid.query.QueryContext
- isSerializeDateTimeAsLongInner(boolean) - Method in class org.apache.druid.query.QueryContext
- isSet(int) - Method in enum org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.Feature
- isShutdown() - Method in class org.apache.druid.java.util.common.concurrent.DirectExecutorService
- 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
- isSorted() - Method in interface org.apache.druid.segment.data.DictionaryWriter
- isSorted() - Method in class org.apache.druid.segment.data.EncodedStringDictionaryWriter
- isSorted() - Method in class org.apache.druid.segment.data.FixedIndexed
- isSorted() - Method in class org.apache.druid.segment.data.FixedIndexedWriter
- isSorted() - Method in class org.apache.druid.segment.data.FrontCodedIndexed
- isSorted() - Method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
- isSorted() - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexed
- isSorted() - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- isSorted() - Method in class org.apache.druid.segment.data.GenericIndexed.BufferIndexed
- isSorted() - Method in class org.apache.druid.segment.data.GenericIndexed
- isSorted() - Method in class org.apache.druid.segment.data.GenericIndexedWriter
- isSorted() - Method in interface org.apache.druid.segment.data.Indexed
-
Indicates if this value set is sorted, the implication being that the contract of
Indexed.indexOf(T)
is strenthened to return a negative number equal to (-(insertion point) - 1) when the value is not present in the set. - isSorted() - Method in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
- isSorted() - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- isSorted() - Method in class org.apache.druid.segment.serde.ReplaceFirstValueWithNullIndexed
- isSparse - Variable in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- isSpillingAllowed() - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
- isSplittable() - Method in interface org.apache.druid.data.input.FirehoseFactory
-
Deprecated.
- isSplittable() - Method in class org.apache.druid.data.input.impl.CsvInputFormat
- isSplittable() - Method in class org.apache.druid.data.input.impl.DelimitedInputFormat
- isSplittable() - Method in class org.apache.druid.data.input.impl.InlineInputSource
- isSplittable() - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- isSplittable() - Method in class org.apache.druid.data.input.impl.RegexInputFormat
- isSplittable() - Method in interface org.apache.druid.data.input.impl.SplittableInputSource
- isSplittable() - Method in interface org.apache.druid.data.input.InputFormat
-
Trait to indicate that a file can be split into multiple
InputSplit
s. - isSplittable() - Method in interface org.apache.druid.data.input.InputSource
-
Returns true if this inputSource can be processed in parallel using ParallelIndexSupervisorTask.
- isStandard(Granularity) - Static method in enum org.apache.druid.java.util.common.granularity.GranularityType
-
For a select subset of granularites, users can specify them directly as string.
- isStart() - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- isStart() - Method in class org.apache.druid.timeline.partition.LinearPartitionChunk
- isStart() - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- isStart() - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- isStart() - Method in interface org.apache.druid.timeline.partition.PartitionChunk
-
Returns true if this chunk is the beginning of the partition.
- isStart() - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- isStart() - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- isStart() - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- isStarted() - Method in class org.apache.druid.common.config.Log4jShutdown
- isStarted() - Method in class org.apache.druid.concurrent.LifecycleLock
-
Returns
true
ifLifecycleLock.started()
was called before that. - isStarted() - Method in class org.apache.druid.java.util.metrics.AbstractMonitor
- isStopped() - Method in class org.apache.druid.common.config.Log4jShutdown
- isSuccess() - Method in enum org.apache.druid.indexer.TaskState
- isSuccess() - Method in class org.apache.druid.indexer.TaskStatus
-
Returned by tasks when they spawn subtasks.
- isSupportConnected() - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
- isTableBased() - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
Returns whether this datasource is one of:
TableDataSource
UnionDataSource
composed entirely ofTableDataSource
UnnestDataSource
composed entirely ofTableDataSource
- isTerminated() - Method in class org.apache.druid.java.util.common.concurrent.DirectExecutorService
- isTerminated() - Method in class org.apache.druid.query.PrioritizedExecutorService
- isThreadCpuTimeEnabled() - Static method in class org.apache.druid.utils.JvmUtils
- isTimeBoundaryPlanningEnabled() - Method in class org.apache.druid.query.QueryContext
- isTombstone() - Method in class org.apache.druid.timeline.DataSegment
- isTraceEnabled() - Method in class org.apache.druid.java.util.common.logger.Logger
- isTriviallyComplete() - Method in class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- isTrue() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- IsTrueDimFilter - Class in org.apache.druid.query.filter
- IsTrueDimFilter(DimFilter) - Constructor for class org.apache.druid.query.filter.IsTrueDimFilter
- IsTrueFunc() - Constructor for class org.apache.druid.math.expr.Function.IsTrueFunc
- isTruncated() - Method in class org.apache.druid.query.context.ResponseContext.SerializationResult
- isUnknown() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- isUpperOpen() - Method in class org.apache.druid.query.filter.RangeFilter
- isUpperStrict() - Method in class org.apache.druid.query.filter.BoundDimFilter
- isUpperUnbounded() - Method in class org.apache.druid.query.operator.window.WindowFrame
- isUseCache() - Method in class org.apache.druid.query.QueryContext
- isUseCache(boolean) - Method in class org.apache.druid.query.QueryContext
- isUseDefaultValuesForNull() - Method in class org.apache.druid.common.config.NullValueHandlingConfig
- isUseExtensionClassloaderFirst() - Method in class org.apache.druid.guice.ExtensionsConfig
- isUseFieldDiscovery() - Method in class org.apache.druid.java.util.common.parsers.JSONPathSpec
- isUseIntegerDeltas() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnHeader
- isUseJsonNodeReader() - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- isUseNestedForUnknownTypeInSubquery(boolean) - Method in class org.apache.druid.query.QueryContext
- isUseResultLevelCache() - Method in class org.apache.druid.query.QueryContext
- isUseResultLevelCache(boolean) - Method in class org.apache.druid.query.QueryContext
- isUseStrictBooleans() - Method in class org.apache.druid.math.expr.ExpressionProcessingConfig
- isUseThreeValueLogicForNativeFilters() - Method in class org.apache.druid.common.config.NullValueHandlingConfig
- isUsingDefaultInterval() - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- isValid() - Method in class org.apache.druid.segment.data.SafeWritableBase
- isValid(Object, ConstraintValidatorContext) - Method in class org.apache.druid.java.util.common.HumanReadableBytesRange.HumanReadableBytesRangeValidator
- 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
- isValue() - Method in class org.apache.druid.java.util.common.Either
- isValueNullOrEmptyCollection() - Method in class org.apache.druid.indexer.Property
- isVariantType() - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- isVariantType(boolean) - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.SerializerBuilder
- isVectorize() - Method in class org.apache.druid.query.groupby.GroupByQueryConfig
- isWhitelist() - Method in class org.apache.druid.query.dimension.ListFilteredDimensionSpec
- isWindowingStrictValidation() - Method in class org.apache.druid.query.QueryContext
- isWithRollup() - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
- isZeroSequence(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Checks whether a word contains a sequence of 0's
- isZip(String) - Static method in class org.apache.druid.utils.CompressionUtils
-
Checks to see if fName is a valid name for a "*.zip" file
- IterableRowsCursorHelper - Class in org.apache.druid.query
-
Helper methods to create cursor from iterable of rows
- IterableRowsCursorHelper() - Constructor for class org.apache.druid.query.IterableRowsCursorHelper
- iterableWithPostAggregations(List<PostAggregator>, boolean) - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- iterableWithPostAggregations(List<PostAggregator>, boolean) - Method in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
- iterateAllObjects() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
-
Returns a lazy collection with all objects (including partially AND fully overshadowed, see
VersionedIntervalTimeline.findFullyOvershadowed()
) in this VersionedIntervalTimeline to be used for iteration orCollection.stream()
transformation. - iterateAllPossibleParsings(String) - Static method in class org.apache.druid.timeline.SegmentId
-
Returns a (potentially empty) lazy iteration of all possible valid parsings of the given segment id string into
SegmentId
objects. - iteratePossibleParsingsWithDataSource(String, String) - Static method in class org.apache.druid.timeline.SegmentId
-
Returns a list of either 0, 1 or 2 elements containing possible parsings if the given segment id String representation with the given data source name.
- 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.CombiningIterable
- iterator() - Method in class org.apache.druid.collections.IntegerSet
- iterator() - Method in class org.apache.druid.collections.RangeIntSet
- iterator() - Method in class org.apache.druid.extendedset.intset.AbstractIntSet
- iterator() - Method in class org.apache.druid.extendedset.intset.ConciseSet
- iterator() - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- iterator() - Method in interface org.apache.druid.extendedset.intset.IntSet
- iterator() - Method in class org.apache.druid.frame.key.ClusterByPartitions
- iterator() - Method in class org.apache.druid.java.util.common.guava.DroppingIterable
- iterator() - Method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- iterator() - Method in class org.apache.druid.java.util.common.guava.MergeIterable
- iterator() - Method in class org.apache.druid.java.util.common.guava.nary.TrinaryTransformIterable
- iterator() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectBufferStore
- iterator() - Method in class org.apache.druid.query.aggregation.SerializedStorage
- iterator() - Method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
- iterator() - Method in class org.apache.druid.query.groupby.epinephelinae.HashVectorGrouper
- iterator() - 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.scan.ScanResultValueFramesIterable
- 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 class org.apache.druid.segment.column.StringEncodingStrategies.Utf8ToStringIndexed
- iterator() - Method in interface org.apache.druid.segment.data.BitmapValues
- iterator() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarMultiIntsSupplier.CompressedVSizeColumnarMultiInts
- iterator() - Method in class org.apache.druid.segment.data.FixedIndexed
- iterator() - Method in class org.apache.druid.segment.data.FrontCodedIndexed
- iterator() - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexed
- iterator() - Method in class org.apache.druid.segment.data.GenericIndexed.BufferIndexed
- 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.DictionaryEncodedColumnMerger.ConvertingBitmapValues
- iterator() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- iterator() - Method in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
- iterator() - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- iterator() - Method in class org.apache.druid.segment.serde.ReplaceFirstValueWithNullIndexed
- iterator() - Method in class org.apache.druid.timeline.partition.PartitionHolder
- 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(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
- iterator(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
- iterator(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.StreamingMergeSortedGrouper
-
Return a sorted iterator.
- iterator(boolean) - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
- iterator(int) - Method in class org.apache.druid.collections.RangeIntSet
J
- JacksonConfigManager - Class in org.apache.druid.common.config
- JacksonConfigManager(ConfigManager, ObjectMapper, AuditManager) - Constructor for class org.apache.druid.common.config.JacksonConfigManager
- JacksonConfigManagerModule - Class in org.apache.druid.guice
- JacksonConfigManagerModule() - Constructor for class org.apache.druid.guice.JacksonConfigManagerModule
- JacksonConfigProvider<T> - Class in org.apache.druid.guice
- JacksonModule - Class in org.apache.druid.jackson
- JacksonModule() - Constructor for class org.apache.druid.jackson.JacksonModule
- JacksonUtils - Class in org.apache.druid.java.util.common.jackson
- 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
- JavaScriptConfig - Class in org.apache.druid.js
-
Should be used by extension filters, aggregators, etc, that use JavaScript to determine if JavaScript is enabled or not.
- JavaScriptConfig(boolean) - Constructor for class org.apache.druid.js.JavaScriptConfig
- JavaScriptDimFilter - Class in org.apache.druid.query.filter
- JavaScriptDimFilter(String, String, ExtractionFn, JavaScriptConfig) - Constructor for class org.apache.druid.query.filter.JavaScriptDimFilter
- JavaScriptDimFilter(String, String, ExtractionFn, FilterTuning, 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
- JavaScriptParser - Class in org.apache.druid.java.util.common.parsers
- JavaScriptParser(String) - Constructor for class org.apache.druid.java.util.common.parsers.JavaScriptParser
- JavaScriptParseSpec - Class in org.apache.druid.data.input.impl
- JavaScriptParseSpec(TimestampSpec, DimensionsSpec, String, JavaScriptConfig) - Constructor for class org.apache.druid.data.input.impl.JavaScriptParseSpec
- 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
- Jerseys - Class in org.apache.druid.guice
- Jerseys() - Constructor for class org.apache.druid.guice.Jerseys
- Jobby - Interface in org.apache.druid.indexer
- JodaUtils - Class in org.apache.druid.java.util.common
- JodaUtils() - Constructor for class org.apache.druid.java.util.common.JodaUtils
- join() - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
- 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
- JOIN_OPERATION - Static variable in class org.apache.druid.segment.join.JoinableFactoryWrapper
- Joinable - Interface in org.apache.druid.segment.join
-
Represents something that can be the right-hand side of a join.
- Joinable.ColumnValuesWithUniqueFlag - Class in org.apache.druid.segment.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. - JoinableFactoryWrapper - Class in org.apache.druid.segment.join
-
A wrapper class over
JoinableFactory
for working withJoinable
related classes. - JoinableFactoryWrapper(JoinableFactory) - Constructor for class org.apache.druid.segment.join.JoinableFactoryWrapper
- JoinConditionAnalysis - Class in org.apache.druid.segment.join
-
Represents analysis of a join condition.
- JoinConfig - Class in org.apache.druid.query.operator.join
- JoinConfig(int) - Constructor for class org.apache.druid.query.operator.join.JoinConfig
- JoinDataSource - Class in org.apache.druid.query
-
Represents a join of two datasources.
- JOINER - Static variable in interface org.apache.druid.segment.loading.DataSegmentPusher
- 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, 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
-
An interface returned by
Joinable.makeJoinMatcher(org.apache.druid.segment.ColumnSelectorFactory, org.apache.druid.segment.join.JoinConditionAnalysis, boolean, boolean, org.apache.druid.java.util.common.io.Closer)
and used byHashJoinEngine
to implement a join. - joinOn(String...) - Method in class org.apache.druid.query.operator.join.JoinPartDefn.Builder
- JoinPartDefn - Class in org.apache.druid.query.operator.join
- JoinPartDefn(Operator, List<String>, List<String>) - Constructor for class org.apache.druid.query.operator.join.JoinPartDefn
- JoinPartDefn.Builder - Class in org.apache.druid.query.operator.join
- JoinPrefixUtils - Class in org.apache.druid.segment.join
-
Utility class for working with prefixes in join operations
- JoinPrefixUtils() - Constructor for class org.apache.druid.segment.join.JoinPrefixUtils
- JoinType - Enum in org.apache.druid.segment.join
- JQ - org.apache.druid.java.util.common.parsers.JSONPathFieldType
- JQ_PATH_ROOT - Static variable in class org.apache.druid.segment.nested.NestedPathFinder
- JS_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- Json - Annotation Type in org.apache.druid.guice.annotations
- JSON_PARSE_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
-
Error codes
- JSON_PATH_ROOT - Static variable in class org.apache.druid.segment.nested.NestedPathFinder
- JsonConfigProvider<T> - Class in org.apache.druid.guice
-
Provides a singleton value of type
<T>
fromProperties
bound in guice. - JsonConfigProvider(String, Class<T>, Class<? extends T>) - Constructor for class org.apache.druid.guice.JsonConfigProvider
- JsonConfigurator - Class in org.apache.druid.guice
- JsonConfigurator(ObjectMapper, Validator) - Constructor for class org.apache.druid.guice.JsonConfigurator
- JSONFlattenerMaker - Class in org.apache.druid.java.util.common.parsers
- JSONFlattenerMaker(boolean, boolean) - Constructor for class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- JsonIncludeFilter() - Constructor for class org.apache.druid.segment.VirtualColumns.JsonIncludeFilter
- JsonInputFormat - Class in org.apache.druid.data.input.impl
- JsonInputFormat(JSONPathSpec, Map<String, Boolean>, Boolean, boolean, Boolean, Boolean) - Constructor for class org.apache.druid.data.input.impl.JsonInputFormat
- JsonInputFormat(JSONPathSpec, Map<String, Boolean>, Boolean, Boolean, Boolean) - Constructor for class org.apache.druid.data.input.impl.JsonInputFormat
- JsonIterator<T> - Class in org.apache.druid.data.input.impl.prefetch
-
An iterator over an array of JSON objects.
- JsonIterator(TypeReference<T>, InputStream, Closeable, ObjectMapper) - Constructor for class org.apache.druid.data.input.impl.prefetch.JsonIterator
- JsonKeysExprMacro() - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.JsonKeysExprMacro
- JsonLineReader - Class in org.apache.druid.data.input.impl
-
JsonLineReader
reads input text line by line and tries to convert each text line to an JSON object. - JSONLowercaseParseSpec - Class in org.apache.druid.data.input.impl
-
Deprecated.
- JSONLowercaseParseSpec(TimestampSpec, DimensionsSpec) - Constructor for class org.apache.druid.data.input.impl.JSONLowercaseParseSpec
-
Deprecated.
- jsonMapper(Properties) - Method in class org.apache.druid.jackson.JacksonModule
- jsonMapperOnlyNonNullValue(Properties) - Method in class org.apache.druid.jackson.JacksonModule
-
Provides ObjectMapper that suppress serializing properties with null values
- JsonNodeReader - Class in org.apache.druid.data.input.impl
-
In contrast to
JsonLineReader
which processes input text line by line independently, this class tries to split the input into a list of JsonNode objects, and then parses each JsonNode independently into an InputRow. - JsonNonNull - Annotation Type in org.apache.druid.guice.annotations
-
The ObjectMapper of this annotation will skip serialization of any field with null value.
- JsonObjectExprMacro() - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.JsonObjectExprMacro
- JSONParseSpec - Class in org.apache.druid.data.input.impl
- JSONParseSpec(TimestampSpec, DimensionsSpec) - Constructor for class org.apache.druid.data.input.impl.JSONParseSpec
- JSONParseSpec(TimestampSpec, DimensionsSpec, JSONPathSpec, Map<String, Boolean>, Boolean) - Constructor for class org.apache.druid.data.input.impl.JSONParseSpec
- JSONPathFieldSpec - Class in org.apache.druid.java.util.common.parsers
- JSONPathFieldSpec(JSONPathFieldType, String, String) - Constructor for class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- JSONPathFieldSpec(JSONPathFieldType, String, String, List<String>) - Constructor for class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- JSONPathFieldType - Enum in org.apache.druid.java.util.common.parsers
- JSONPathParser - Class in org.apache.druid.java.util.common.parsers
-
JSON parser class that uses the JsonPath library to access fields via path expressions.
- JSONPathParser(JSONPathSpec, ObjectMapper, boolean) - Constructor for class org.apache.druid.java.util.common.parsers.JSONPathParser
-
Constructor
- JsonPathsExprMacro() - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.JsonPathsExprMacro
- JSONPathSpec - Class in org.apache.druid.java.util.common.parsers
- JSONPathSpec(Boolean, List<JSONPathFieldSpec>) - Constructor for class org.apache.druid.java.util.common.parsers.JSONPathSpec
- JsonQueryArrayExprMacro() - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.JsonQueryArrayExprMacro
- JsonQueryExprMacro() - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.JsonQueryExprMacro
- JsonReader - Class in org.apache.druid.data.input.impl
-
In contrast to
JsonLineReader
which processes input text line by line independently, this class tries to parse the input text as a whole to an array of objects. - JSONToLowerParser - Class in org.apache.druid.java.util.common.parsers
-
Deprecated.
- JSONToLowerParser(ObjectMapper, Iterable<String>, Iterable<String>) - Constructor for class org.apache.druid.java.util.common.parsers.JSONToLowerParser
-
Deprecated.
- JsonValueExprMacro() - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.JsonValueExprMacro
- JSR311Resource - Annotation Type in org.apache.druid.guice.annotations
- justification() - Method in annotation type org.apache.druid.annotations.SuppressFBWarnings
-
Optional documentation of the reason why the warning is suppressed
- JvmCpuMonitor - Class in org.apache.druid.java.util.metrics
- JvmCpuMonitor() - Constructor for class org.apache.druid.java.util.metrics.JvmCpuMonitor
- JvmCpuMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.JvmCpuMonitor
- JvmCpuMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.JvmCpuMonitor
- JvmMonitor - Class in org.apache.druid.java.util.metrics
- JvmMonitor() - Constructor for class org.apache.druid.java.util.metrics.JvmMonitor
- JvmMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.JvmMonitor
- JvmMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.JvmMonitor
- JvmPidDiscoverer - Class in org.apache.druid.java.util.metrics
-
For systems that for whatever reason cannot use Sigar (through org.apache.druid.java.util.metrics.SigarPidDiscoverer ), this attempts to get the PID from the JVM "name".
- JvmThreadsMonitor - Class in org.apache.druid.java.util.metrics
- JvmThreadsMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.JvmThreadsMonitor
- JvmThreadsMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.JvmThreadsMonitor
- JvmUtils - Class in org.apache.druid.utils
- JvmUtils() - Constructor for class org.apache.druid.utils.JvmUtils
K
- keep(Function<T, RetType>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- keep(Function<T, RetType>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- keepOnlyN(int) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm.BaseArrayProvider
- keepOnlyN(int) - Method in interface org.apache.druid.query.topn.TopNMetricSpecBuilder
- key(String) - Method in class org.apache.druid.audit.AuditEntry.Builder
- 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.
- KeyColumn - Class in org.apache.druid.frame.key
-
Represents a component of a hash or sorting key.
- KeyColumn(String, KeyOrder) - Constructor for class org.apache.druid.frame.key.KeyColumn
- keyColumns() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
- keyColumns() - Method in class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- 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
- keyComparator(RowSignature) - Method in class org.apache.druid.frame.key.ClusterBy
-
Comparator that compares keys for this instance using the given signature.
- KeyedDiff - Class in org.apache.druid.java.util.metrics
- KeyedDiff() - Constructor for class org.apache.druid.java.util.metrics.KeyedDiff
- KeyHolder<T> - Class in org.apache.druid.guice
- KeyHolder(Key<? extends T>) - Constructor for class org.apache.druid.guice.KeyHolder
- KeyMappingMultiValueGroupByColumnSelectorStrategy - Class in org.apache.druid.query.groupby.epinephelinae.column
-
Like
KeyMappingGroupByColumnSelectorStrategy
, but for multi-value dimensions, i.e. - KeyMappingMultiValueGroupByColumnSelectorStrategy() - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy
- KeyMappingMultiValueGroupByColumnSelectorStrategy.DictionaryBuilding - Class in org.apache.druid.query.groupby.epinephelinae.column
- KeyMappingMultiValueGroupByColumnSelectorStrategy.PrebuiltDictionary - Class in org.apache.druid.query.groupby.epinephelinae.column
- keyOf(String) - Method in class org.apache.druid.query.context.ResponseContext.Keys
-
Returns a registered key associated with the name {@param name}.
- KeyOrder - Enum in org.apache.druid.frame.key
-
Ordering associated with a
KeyColumn
. - keyReader(ColumnInspector) - Method in class org.apache.druid.frame.key.ClusterBy
-
Create a reader for keys for this instance.
- keySerde - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- keySet() - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
- 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) - keyType() - Method in interface org.apache.druid.segment.join.table.IndexedTable.Index
-
Returns the natural key type for the index.
- keyType() - Method in class org.apache.druid.segment.join.table.MapIndex
- keyType() - Method in class org.apache.druid.segment.join.table.UniqueLongArrayIndex
- kill(List<DataSegment>) - Method in interface org.apache.druid.segment.loading.DataSegmentKiller
-
Kills a list of segments from deep storage.
- kill(DataSegment) - Method in interface org.apache.druid.segment.loading.DataSegmentKiller
-
Removes segment files (index and metadata) from deep storage.
- killAll() - Method in interface org.apache.druid.segment.loading.DataSegmentKiller
-
Like a nuke.
- killAll() - Method in class org.apache.druid.tasklogs.NoopTaskLogs
- killAll() - Method in interface org.apache.druid.tasklogs.TaskLogKiller
- killOlderThan(long) - Method in class org.apache.druid.tasklogs.NoopTaskLogs
- killOlderThan(long) - Method in interface org.apache.druid.tasklogs.TaskLogKiller
-
Removes logs older than the provided timestamp
- killQuietly(DataSegment) - Method in interface org.apache.druid.segment.loading.DataSegmentKiller
-
A more stoic killer who doesn't throw a tantrum if things get messy.
- KillTaskReport - Class in org.apache.druid.indexer.report
- KillTaskReport(String, KillTaskReport.Stats) - Constructor for class org.apache.druid.indexer.report.KillTaskReport
- KillTaskReport.Stats - Class in org.apache.druid.indexer.report
- kilometers - org.apache.druid.collections.spatial.search.RadiusBound.RadiusUnit
- KLL_DOUBLES_SKETCH_BUILD_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- KLL_DOUBLES_SKETCH_MERGE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- KLL_DOUBLES_SKETCH_TO_CDF_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_DOUBLES_SKETCH_TO_HISTOGRAM_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_DOUBLES_SKETCH_TO_QUANTILE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_DOUBLES_SKETCH_TO_QUANTILES_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_DOUBLES_SKETCH_TO_RANK_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_DOUBLES_SKETCH_TO_STRING_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_FLOATS_SKETCH_BUILD_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- KLL_FLOATS_SKETCH_MERGE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- KLL_FLOATS_SKETCH_TO_CDF_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_FLOATS_SKETCH_TO_HISTOGRAM_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_FLOATS_SKETCH_TO_QUANTILE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_FLOATS_SKETCH_TO_QUANTILES_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_FLOATS_SKETCH_TO_RANK_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- KLL_FLOATS_SKETCH_TO_STRING_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
L
- lambda() - Method in class org.apache.druid.math.expr.antlr.ExprParser.ApplyFunctionExprContext
- lambda() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- LambdaContext(ParserRuleContext, int) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.LambdaContext
- LambdaInputBindingInspector(Expr.InputBindingInspector, LambdaExpr, List<Expr>) - Constructor for class org.apache.druid.math.expr.ApplyFunction.LambdaInputBindingInspector
- LANE_KEY - Static variable in class org.apache.druid.query.QueryContexts
- LargeColumnSupportedComplexColumnSerializer<T> - Class in org.apache.druid.segment.serde
- last() - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- LAST_PREDICATE - Static variable in interface org.apache.druid.query.aggregation.firstlast.SelectionPredicate
- lastBucketNumValues - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- lastCompactionState(CompactionState) - Method in class org.apache.druid.timeline.DataSegment.Builder
- lastInt() - Method in class org.apache.druid.collections.RangeIntSet
- lastTime - Variable in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- lastValue - Variable in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- laterOf(DateTime, DateTime) - Static method in class org.apache.druid.java.util.common.DateTimes
-
Returns the later of the two given dates.
- LATEST - org.apache.druid.query.metadata.metadata.AggregatorMergeStrategy
- LazilyDecoratedRowsAndColumns - Class in org.apache.druid.query.rowsandcols
- LazilyDecoratedRowsAndColumns(RowsAndColumns, Interval, Filter, VirtualColumns, OffsetLimit, List<ColumnWithDirection>, LinkedHashSet<String>) - Constructor for class org.apache.druid.query.rowsandcols.LazilyDecoratedRowsAndColumns
- LAZY_DISCRETE_UNIFORM - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- LAZY_ZIPF - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- lazyParse(String, ExprMacroTable) - Static method in class org.apache.druid.math.expr.Parser
-
Create a memoized lazy supplier to parse a string into a flattened
Expr
. - LazySequence<T> - Class in org.apache.druid.java.util.common.guava
- LazySequence(Supplier<Sequence<T>>) - Constructor for class org.apache.druid.java.util.common.guava.LazySequence
- LazySingleton - Annotation Type in org.apache.druid.guice
-
A replacement for Guice's Singleton scope.
- leakedResources() - Static method in class org.apache.druid.collections.ReferenceCountingResourceHolder
- LeastFunc() - Constructor for class org.apache.druid.math.expr.Function.LeastFunc
- leastRestrictiveType(ExpressionType, ExpressionType) - Static method in class org.apache.druid.math.expr.ExpressionTypeConversion
-
ColumnType.leastRestrictiveType(ColumnType, ColumnType)
but for expression types - leastRestrictiveType(ColumnType, ColumnType) - Static method in class org.apache.druid.segment.column.ColumnType
-
Finds the type that can best represent both types, or none if there is no type information.
- LEFT - org.apache.druid.segment.join.JoinType
- LeftFunc() - Constructor for class org.apache.druid.math.expr.Function.LeftFunc
- 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.extendedset.utilities.IntList
- length() - Method in class org.apache.druid.frame.allocation.MemoryRange
- length() - Method in interface org.apache.druid.frame.field.ReadableFieldPointer
-
Length of the field.
- length() - Method in class org.apache.druid.frame.field.RowMemoryFieldPointer
- length() - Method in class org.apache.druid.frame.field.SettableFieldPointer
- length() - Method in class org.apache.druid.frame.segment.row.ConstantFrameRowPointer
- length() - Method in class org.apache.druid.frame.segment.row.CursorFrameRowPointer
- length() - Method in interface org.apache.druid.frame.segment.row.ReadableFrameRowPointer
-
Length of the row (in bytes)
- length() - Method in class org.apache.druid.query.groupby.ResultRow
- length() - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix.MatrixRow
- 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
-
Returns the row count of this column.
- length() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- length() - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- length() - Method in class org.apache.druid.segment.nested.VariantColumn
- length(Object) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- LENIENT - org.apache.druid.query.metadata.metadata.AggregatorMergeStrategy
- lenientAggregatorMerge(boolean) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
-
Deprecated.
- LEQ - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- LEQ - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- lessThan(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorComparisonProcessors
- 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
- lessThanOrEqual(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorComparisonProcessors
- 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
- LexicographicalRangeIndexes - Interface in org.apache.druid.segment.index.semantic
-
An optimized column value
BitmapColumnIndex
provider for columns which are stored in 'lexicographical' order, allowing short-circuit processing of string value ranges. - 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
- lhs - Variable in class org.apache.druid.java.util.common.NonnullPair
- lhs - Variable in class org.apache.druid.java.util.common.Pair
- Lifecycle - Class in org.apache.druid.java.util.common.lifecycle
-
A manager of object Lifecycles.
- Lifecycle() - Constructor for class org.apache.druid.java.util.common.lifecycle.Lifecycle
- Lifecycle(String) - Constructor for class org.apache.druid.java.util.common.lifecycle.Lifecycle
- Lifecycle.Handler - Interface in org.apache.druid.java.util.common.lifecycle
- Lifecycle.Stage - Enum in org.apache.druid.java.util.common.lifecycle
- LifecycleForkJoinPoolProvider - Class in org.apache.druid.guice
- LifecycleForkJoinPoolProvider(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean, long) - Constructor for class org.apache.druid.guice.LifecycleForkJoinPoolProvider
- LifecycleLock - Class in org.apache.druid.concurrent
-
A synchronization tool for lifecycled objects (see
Lifecycle
, that need happens-before between start() and other methods and/or to check that the object was successfully started in other methods. - LifecycleLock() - Constructor for class org.apache.druid.concurrent.LifecycleLock
- LifecycleModule - Class in org.apache.druid.guice
-
A Module to add lifecycle management to the injector.
- LifecycleModule() - Constructor for class org.apache.druid.guice.LifecycleModule
- LifecycleScope - Class in org.apache.druid.guice
-
A scope that adds objects to the Lifecycle.
- LifecycleScope(Lifecycle.Stage) - Constructor for class org.apache.druid.guice.LifecycleScope
- LifecycleStart - Annotation Type in org.apache.druid.java.util.common.lifecycle
- LifecycleStop - Annotation Type in org.apache.druid.java.util.common.lifecycle
- LikeDimFilter - Class in org.apache.druid.query.filter
- LikeDimFilter(String, String, String, ExtractionFn) - Constructor for class org.apache.druid.query.filter.LikeDimFilter
- LikeDimFilter(String, String, String, ExtractionFn, FilterTuning) - 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 - Variable in class org.apache.druid.query.operator.OffsetLimit
- limit(int) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- 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(int) - Static method in class org.apache.druid.query.operator.OffsetLimit
- limit(long) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- limit(long) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- 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
- LimitedColumn - Class in org.apache.druid.query.rowsandcols.column
- LimitedColumn(Column, int, int) - Constructor for class org.apache.druid.query.rowsandcols.column.LimitedColumn
- LimitedRowsAndColumns - Class in org.apache.druid.query.rowsandcols
- LimitedRowsAndColumns(RowsAndColumns, int, int) - Constructor for class org.apache.druid.query.rowsandcols.LimitedRowsAndColumns
- 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
- LimitJsonIncludeFilter() - Constructor for class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.LimitJsonIncludeFilter
- LimitSpec - Interface in org.apache.druid.query.groupby.orderby
- LimitTimeIntervalOperator - Class in org.apache.druid.query.operator
- LimitTimeIntervalOperator(Operator, Interval) - Constructor for class org.apache.druid.query.operator.LimitTimeIntervalOperator
- limitTimeRange(Interval) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- limitTimeRange(Interval) - Method in interface org.apache.druid.query.rowsandcols.semantic.RowsAndColumnsDecorator
- LINEAR - org.apache.druid.indexer.partitions.SecondaryPartitionType
-
Linear partitioning partitions segments in the same time chunk based on their size or number of rows in them.
- LINEAR - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- LinearGutmanSplitStrategy - Class in org.apache.druid.collections.spatial.split
- LinearGutmanSplitStrategy(int, int, BitmapFactory) - Constructor for class org.apache.druid.collections.spatial.split.LinearGutmanSplitStrategy
- LinearPartialShardSpec - Class in org.apache.druid.timeline.partition
- LinearPartitionChunk<T> - Class in org.apache.druid.timeline.partition
- LinearPartitionChunk(int, T) - Constructor for class org.apache.druid.timeline.partition.LinearPartitionChunk
- LinearShardSpec - Class in org.apache.druid.timeline.partition
-
An extendable linear shard spec.
- LinearShardSpec(Integer) - Constructor for class org.apache.druid.timeline.partition.LinearShardSpec
- LINK - org.apache.druid.java.util.common.FileUtils.LinkOrCopyResult
- linkOrCopy(File, File) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Hard-link "src" as "dest", if possible.
- list() - Static method in class org.apache.druid.java.util.common.guava.Accumulators
- ListBasedInputRow - Class in org.apache.druid.data.input
-
Input row backed by a
List
. - ListBasedInputRow(RowSignature, DateTime, List<String>, List<Object>) - Constructor for class org.apache.druid.data.input.ListBasedInputRow
-
Create a row.
- ListBasedInputRowAdapter - Class in org.apache.druid.data.input
-
Adapter for reading
ListBasedInputRow
. - ListBasedInputRowAdapter(RowSignature) - Constructor for class org.apache.druid.data.input.ListBasedInputRowAdapter
- ListColumnIncluderator - Class in org.apache.druid.query.metadata.metadata
- ListColumnIncluderator(List<String>) - Constructor for class org.apache.druid.query.metadata.metadata.ListColumnIncluderator
- listDir(String) - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
- listDir(String) - Method in class org.apache.druid.storage.NilStorageConnector
- listDir(String) - Method in interface org.apache.druid.storage.StorageConnector
-
Returns a lazy iterator containing all the files present in the path.
- ListFilteredDimensionSpec - Class in org.apache.druid.query.dimension
- ListFilteredDimensionSpec(DimensionSpec, Set<String>, Boolean) - Constructor for class org.apache.druid.query.dimension.ListFilteredDimensionSpec
- ListFilteredDimensionSpec.IndexedGetter<T> - Interface in org.apache.druid.query.dimension
- ListFilteredVirtualColumn - Class in org.apache.druid.segment.virtual
- ListFilteredVirtualColumn(String, DimensionSpec, Set<String>, Boolean) - Constructor for class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- 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
- ListProvider<T> - Class in org.apache.druid.guice
- ListProvider() - Constructor for class org.apache.druid.guice.ListProvider
- literalElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitArrayContext
- literalElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitStringArrayContext
- literalElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- literalElement(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitArrayContext
- literalElement(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitStringArrayContext
- LiteralElementContext(ParserRuleContext, int) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.LiteralElementContext
- load(File) - Static method in class org.apache.druid.java.util.common.io.smoosh.SmooshedFileMapper
- loadBlock(long) - Method in class org.apache.druid.segment.data.CompressedBlockReader
-
Load the block for the specified virtual offset, returning the relative offset into
CompressedBlockReader.decompressedDataBuffer
of theCompressedBlockReader.currentBlockNumber
. - loadClass(String) - Method in class org.apache.druid.guice.ExtensionFirstClassLoader
- loadClass(String, boolean) - Method in class org.apache.druid.guice.ExtensionFirstClassLoader
- loadDimensionIterable(Iterable<String>, Map<String, ColumnFormat>) - 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, SegmentLazyLoadFailCallback) - Method in class org.apache.druid.segment.IndexIO
- loadInternalFile(SmooshedFileMapper, String, String) - Static method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- loadSegment(File) - Method in interface org.apache.druid.segment.loading.LoadSpec
-
Method should put the segment files in the directory passed
- loadSegment(File) - Method in class org.apache.druid.segment.loading.TombstoneLoadSpec
- loadSpec(Map<String, Object>) - Method in class org.apache.druid.timeline.DataSegment.Builder
- LoadSpec - Interface in org.apache.druid.segment.loading
-
A means of pulling segment files into a destination directory
- LoadSpec.LoadSpecResult - Class in org.apache.druid.segment.loading
- LoadSpecResult(long) - Constructor for class org.apache.druid.segment.loading.LoadSpec.LoadSpecResult
- localDictionary - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- LocalDimensionDictionary - Class in org.apache.druid.segment.nested
- LocalDimensionDictionary() - Constructor for class org.apache.druid.segment.nested.LocalDimensionDictionary
- LocalFileExportStorageProvider - Class in org.apache.druid.storage.local
- LocalFileExportStorageProvider(String) - Constructor for class org.apache.druid.storage.local.LocalFileExportStorageProvider
- LocalFileStorageConnector - Class in org.apache.druid.storage.local
-
Implementation that uses local filesystem.
- LocalFileStorageConnector(File) - Constructor for class org.apache.druid.storage.local.LocalFileStorageConnector
- LocalFileStorageConnectorProvider - Class in org.apache.druid.storage.local
- LocalFileStorageConnectorProvider(File) - Constructor for class org.apache.druid.storage.local.LocalFileStorageConnectorProvider
- LocalInputSource - Class in org.apache.druid.data.input.impl
- LocalInputSource(File, String) - Constructor for class org.apache.druid.data.input.impl.LocalInputSource
- LocalInputSource(File, String, List<File>, SystemFields) - Constructor for class org.apache.druid.data.input.impl.LocalInputSource
- LocalInputSourceFactory - Class in org.apache.druid.data.input.impl
- LocalInputSourceFactory() - Constructor for class org.apache.druid.data.input.impl.LocalInputSourceFactory
- LocationWithSize(String, String, long) - Constructor for class org.apache.druid.data.input.impl.CloudObjectSplitWidget.LocationWithSize
- LocationWithSize(CloudObjectLocation, long) - Constructor for class org.apache.druid.data.input.impl.CloudObjectSplitWidget.LocationWithSize
- log - Static variable in class org.apache.druid.java.util.common.RetryUtils
- log - Static variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- log - Variable in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- log - Static variable in interface org.apache.druid.segment.IndexMerger
- log - Static variable in interface org.apache.druid.segment.loading.DataSegmentKiller
- log - Static variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- log(String, Object...) - Method in interface org.apache.druid.java.util.common.logger.Logger.LogFunction
- log(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Log() - Constructor for class org.apache.druid.math.expr.Function.Log
- LOG - Static variable in interface org.apache.druid.data.input.InputEntity
- log10(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Log10() - Constructor for class org.apache.druid.math.expr.Function.Log10
- log1p(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Log1p() - Constructor for class org.apache.druid.math.expr.Function.Log1p
- Log4jShutdown - Class in org.apache.druid.common.config
- Log4jShutdown() - Constructor for class org.apache.druid.common.config.Log4jShutdown
- Logger - Class in org.apache.druid.java.util.common.logger
-
A Logger for usage inside of Druid.
- Logger(Class) - Constructor for class org.apache.druid.java.util.common.logger.Logger
- Logger(String) - Constructor for class org.apache.druid.java.util.common.logger.Logger
- Logger(Logger, boolean) - Constructor for class org.apache.druid.java.util.common.logger.Logger
- Logger.LogFunction - Interface in org.apache.druid.java.util.common.logger
- LoggingEmitter - Class in org.apache.druid.java.util.emitter.core
- LoggingEmitter(Logger, LoggingEmitter.Level, ObjectMapper) - Constructor for class org.apache.druid.java.util.emitter.core.LoggingEmitter
- LoggingEmitter(LoggingEmitterConfig, ObjectMapper) - Constructor for class org.apache.druid.java.util.emitter.core.LoggingEmitter
- LoggingEmitter.Level - Enum in org.apache.druid.java.util.emitter.core
- LoggingEmitterConfig - Class in org.apache.druid.java.util.emitter.core
- LoggingEmitterConfig() - Constructor for class org.apache.druid.java.util.emitter.core.LoggingEmitterConfig
- LoggingEmitterFactory - Class in org.apache.druid.java.util.emitter.factory
- LoggingEmitterFactory() - Constructor for class org.apache.druid.java.util.emitter.factory.LoggingEmitterFactory
- LogicalAndOrExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.LogicalAndOrExprContext
- LogicalOpExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.LogicalOpExprContext
- LogicalSegment - Interface in org.apache.druid.timeline
-
A logical segment can represent an entire segment or a part of a segment.
- LogicalSegment.Status - Enum in org.apache.druid.timeline
- logParseExceptionHelper(Exception) - Method in class org.apache.druid.segment.incremental.ParseExceptionHandler
- LONG - org.apache.druid.math.expr.ExprType
- LONG - org.apache.druid.segment.column.ValueType
-
64-bit integer number primitve type.
- LONG - org.apache.druid.segment.MetricHolder.MetricType
- LONG - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- LONG - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- LONG - Static variable in class org.apache.druid.math.expr.ExpressionType
- LONG - Static variable in class org.apache.druid.segment.column.ColumnType
-
Druid 64-bit integer number primitive type.
- LONG - Static variable in class org.apache.druid.segment.column.TypeStrategies
- LONG() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LiteralElementContext
- LONG() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongElementContext
- LONG() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongExprContext
- LONG() - Method in class org.apache.druid.math.expr.antlr.ExprParser.NumericElementContext
- LONG_ANY_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- LONG_ARRAY - Static variable in class org.apache.druid.math.expr.ExpressionType
- LONG_ARRAY - Static variable in class org.apache.druid.segment.column.ColumnType
-
An array of Longs.
- LONG_COMPARATOR - Static variable in class org.apache.druid.segment.LongDimensionIndexer
- LONG_DICTIONARY_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- LONG_DICTIONARY_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- 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_MERGING_COMPARATOR - Static variable in class org.apache.druid.segment.AutoTypeColumnMerger
- LONG_MERGING_COMPARATOR - Static variable in class org.apache.druid.segment.NestedDataColumnMergerV4
- 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
- LONG_TYPE_NAME - Static variable in class org.apache.druid.data.input.impl.DimensionSchema
- LONG_VALUE_COLUMN_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- 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
- LongArrayContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.LongArrayContext
- LongArrayFieldReader - Class in org.apache.druid.frame.field
-
Reader for fields written by
NumericArrayFieldWriter.getLongArrayFieldWriter(org.apache.druid.segment.ColumnValueSelector)
- LongArrayFieldReader() - Constructor for class org.apache.druid.frame.field.LongArrayFieldReader
- LongArrayFrameColumnReader - Class in org.apache.druid.frame.read.columnar
-
Reader for columns written by
LongArrayFrameColumnWriter
- LongArrayFrameColumnReader(int) - Constructor for class org.apache.druid.frame.read.columnar.LongArrayFrameColumnReader
- LongArrayFrameColumnWriter - Class in org.apache.druid.frame.write.columnar
-
Columnar frame writer for
ColumnType.LONG_ARRAY
columns - LongArrayFrameColumnWriter(ColumnValueSelector, MemoryAllocator) - Constructor for class org.apache.druid.frame.write.columnar.LongArrayFrameColumnWriter
- 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
- LongCardinalityVectorProcessor - Class in org.apache.druid.query.aggregation.cardinality.vector
- LongCardinalityVectorProcessor(VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.cardinality.vector.LongCardinalityVectorProcessor
- LongColumnAccessorBase - Class in org.apache.druid.query.rowsandcols.column.accessor
- LongColumnAccessorBase() - Constructor for class org.apache.druid.query.rowsandcols.column.accessor.LongColumnAccessorBase
- LongColumnSelector - Interface in org.apache.druid.segment
-
This interface is convenient for implementation of "long-sourcing"
ColumnValueSelector
s, it provides default implementations for allColumnValueSelector
's methods exceptBaseLongColumnValueSelector.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.
- LongConstantAggregator - Class in org.apache.druid.query.aggregation.constant
-
This aggregator is a no-op aggregator with a fixed non-null output value.
- LongConstantAggregator(long) - Constructor for class org.apache.druid.query.aggregation.constant.LongConstantAggregator
- LongConstantBufferAggregator - Class in org.apache.druid.query.aggregation.constant
-
BufferAggregator
variant ofLongConstantAggregator
- LongConstantBufferAggregator(long) - Constructor for class org.apache.druid.query.aggregation.constant.LongConstantBufferAggregator
- LongConstantVectorAggregator - Class in org.apache.druid.query.aggregation.constant
-
VectorAggregator
variant ofLongConstantAggregator
- LongConstantVectorAggregator(long) - Constructor for class org.apache.druid.query.aggregation.constant.LongConstantVectorAggregator
- 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
- LongDimensionSchema - Class in org.apache.druid.data.input.impl
- LongDimensionSchema(String) - Constructor for class org.apache.druid.data.input.impl.LongDimensionSchema
- longDivide(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- longElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongArrayContext
- longElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- longElement(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongArrayContext
- LongElementContext(ParserRuleContext, int) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.LongElementContext
- LongExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.LongExprContext
- LongFieldReader - Class in org.apache.druid.frame.field
-
Reads values written by
LongFieldWriter
. - LongFieldWriter - Class in org.apache.druid.frame.field
-
Wraps a
BaseLongColumnValueSelector
and writes individual values into frame rows. - LongFirstAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- LongFirstAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregator
- LongFirstAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.first
- LongFirstAggregatorFactory(String, String, String) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- LongFirstBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- LongFirstBufferAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.LongFirstBufferAggregator
- LongFirstLastVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast
-
Vectorized version of on heap 'last' aggregator for column selectors with type LONG..
- LongFirstLastVectorAggregator(VectorValueSelector, VectorObjectSelector, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- LongFirstLastVectorAggregator(VectorValueSelector, VectorValueSelector, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- LongFirstVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- LongFirstVectorAggregator(VectorValueSelector, VectorObjectSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.LongFirstVectorAggregator
- LongFirstVectorAggregator(VectorValueSelector, VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.LongFirstVectorAggregator
- LongFrameColumnReader - Class in org.apache.druid.frame.read.columnar
- LongFrameColumnWriter - Class in org.apache.druid.frame.write.columnar
- LongFrameMaker - Class in org.apache.druid.frame.write.columnar
- LongFrameMaker(MemoryAllocator, boolean) - Constructor for class org.apache.druid.frame.write.columnar.LongFrameMaker
- LongGreatestPostAggregator - Class in org.apache.druid.query.aggregation.post
- LongGreatestPostAggregator(String, List<PostAggregator>) - Constructor for class org.apache.druid.query.aggregation.post.LongGreatestPostAggregator
- LongGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
- longHashCode() - Method in class org.apache.druid.frame.key.RowKey
- LongLastAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- LongLastAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregator
- LongLastAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.last
- LongLastAggregatorFactory(String, String, String) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- LongLastBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- LongLastBufferAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.LongLastBufferAggregator
- LongLastVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- LongLastVectorAggregator(VectorValueSelector, VectorObjectSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.LongLastVectorAggregator
- LongLastVectorAggregator(VectorValueSelector, VectorValueSelector) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.LongLastVectorAggregator
- 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) - Constructor for class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
- LongMaxAggregatorFactory(String, String, String, ExprMacroTable) - 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) - Constructor for class org.apache.druid.query.aggregation.LongMinAggregatorFactory
- LongMinAggregatorFactory(String, String, String, ExprMacroTable) - 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.NilVectorAggregator
- 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
- LongOutDoubleInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
UnivariateLongFunctionVectorValueProcessor
for processing (long[]) -> long[] - LongOutDoubleInFunctionVectorValueProcessor(ExprVectorProcessor<double[]>, int) - Constructor for class org.apache.druid.math.expr.vector.LongOutDoubleInFunctionVectorValueProcessor
- LongOutDoubleLongInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
BivariateLongFunctionVectorValueProcessor
for processing (double[], long[]) -> long[] - LongOutDoubleLongInFunctionVectorValueProcessor(ExprVectorProcessor<double[]>, ExprVectorProcessor<long[]>, int) - Constructor for class org.apache.druid.math.expr.vector.LongOutDoubleLongInFunctionVectorValueProcessor
- LongOutDoublesInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
BivariateLongFunctionVectorValueProcessor
for processing (double[], double[]) -> long[] - LongOutDoublesInFunctionVectorValueProcessor(ExprVectorProcessor<double[]>, ExprVectorProcessor<double[]>, int) - Constructor for class org.apache.druid.math.expr.vector.LongOutDoublesInFunctionVectorValueProcessor
- LongOutLongDoubleInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
BivariateLongFunctionVectorValueProcessor
for processing (long[], double[]) -> long[] - LongOutLongDoubleInFunctionVectorValueProcessor(ExprVectorProcessor<long[]>, ExprVectorProcessor<double[]>, int) - Constructor for class org.apache.druid.math.expr.vector.LongOutLongDoubleInFunctionVectorValueProcessor
- LongOutLongInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
UnivariateLongFunctionVectorValueProcessor
for processing (long[]) -> long[] - LongOutLongInFunctionVectorValueProcessor(ExprVectorProcessor<long[]>, int) - Constructor for class org.apache.druid.math.expr.vector.LongOutLongInFunctionVectorValueProcessor
- LongOutLongsInFunctionVectorValueProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
BivariateLongFunctionVectorValueProcessor
for processing (long[], long[]) -> long[] - LongOutLongsInFunctionVectorValueProcessor(ExprVectorProcessor<long[]>, ExprVectorProcessor<long[]>, int) - Constructor for class org.apache.druid.math.expr.vector.LongOutLongsInFunctionVectorValueProcessor
- LongOutObjectInFunctionVectorProcessor - Class in org.apache.druid.math.expr.vector
-
specialized
UnivariateFunctionVectorObjectProcessor
for processing (Object[]) -> long[] - LongOutObjectInFunctionVectorProcessor(ExprVectorProcessor<Object[]>, int, ExpressionType) - Constructor for class org.apache.druid.math.expr.vector.LongOutObjectInFunctionVectorProcessor
- LongOutObjectsInFunctionVectorProcessor - Class in org.apache.druid.math.expr.vector
- LongOutObjectsInFunctionVectorProcessor(ExprVectorProcessor<Object[]>, ExprVectorProcessor<Object[]>, int, ExpressionType) - Constructor for class org.apache.druid.math.expr.vector.LongOutObjectsInFunctionVectorProcessor
- LONGS - org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
-
LONGS format encodes longs as is, using 8 bytes for each value.
- LONGS - org.apache.druid.segment.data.CompressionFactory.LongEncodingStrategy
-
LONGS strategy always encode the values using LONGS format
- LongsColumn - Class in org.apache.druid.segment.column
- LongSearchColumnSelectorStrategy() - Constructor for class org.apache.druid.query.search.SearchQueryRunner.LongSearchColumnSelectorStrategy
- LongSerializer - Class in org.apache.druid.segment.serde.cell
- LongSerializer() - Constructor for class org.apache.druid.segment.serde.cell.LongSerializer
- 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) - Constructor for class org.apache.druid.query.aggregation.LongSumAggregatorFactory
- LongSumAggregatorFactory(String, String, String, ExprMacroTable) - 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, Object>) - Constructor for class org.apache.druid.query.topn.types.LongTopNColumnAggregatesProcessor
- LongTypeStrategy() - Constructor for class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- 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(String, String, String, String) - Method in interface org.apache.druid.metadata.MetadataStorageConnector
-
Returns the value of the valueColumn when there is only one row matched to the given key.
- 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
- lookup(Interval) - Method in interface org.apache.druid.timeline.TimelineLookup
-
Does a lookup for the objects representing the given time interval.
- lookup(Interval) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
-
Does a lookup for the objects representing the given time interval.
- LOOKUP - Static variable in class org.apache.druid.hll.ByteBitLookup
- lookupArray(int[]) - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- 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
- lookupDouble(Double) - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- 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 typeLookupExtractor
. - 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(DimensionType) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.DimensionIdCodec
- lookupId(String) - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- lookupId(String) - Method in class org.apache.druid.segment.ConstantDimensionSelector
- lookupId(String) - Method in interface org.apache.druid.segment.IdLookup
-
Inverse of
DimensionDictionarySelector.lookupName(int)
. - lookupId(String) - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
- lookupId(String) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- lookupId(String) - Method in class org.apache.druid.segment.nested.VariantColumn
- lookupId(String) - Method in class org.apache.druid.segment.vector.NilVectorSelector
- lookupIds(String) - Method in class org.apache.druid.segment.nested.VariantColumn
- 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
- lookupLong(Long) - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- 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.StringUtf8DictionaryEncodedColumn
- lookupName(int) - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.MultiValueStringVectorObjectSelector
- lookupName(int) - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringVectorObjectSelector
- lookupName(int) - Method in class org.apache.druid.segment.ConstantDimensionSelector
- lookupName(int) - Method in class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- lookupName(int) - Method in interface org.apache.druid.segment.DimensionDictionarySelector
-
Returns the value for a particular dictionary id as a Java String.
- 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.nested.NestedFieldDictionaryEncodedColumn
- lookupName(int) - Method in class org.apache.druid.segment.nested.VariantColumn
- 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.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- lookupName(int) - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector
- lookupNameUtf8(int) - Method in interface org.apache.druid.segment.DimensionDictionarySelector
-
Returns the value for a particular dictionary id as UTF-8 bytes.
- lookupScalarValue(int) - Method in class org.apache.druid.segment.nested.VariantColumn.VariantVectorObjectSelector
- lookupScalarValueAndCast(int) - Method in class org.apache.druid.segment.nested.VariantColumn.VariantVectorObjectSelector
- LookupSegment - Class in org.apache.druid.query.lookup
-
A
Segment
that is based on aLookupExtractor
. - 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
- lookupString(String) - Method in class org.apache.druid.segment.nested.DictionaryIdLookup
- lookupWithIncompletePartitions(Interval) - Method in interface org.apache.druid.timeline.TimelineLookup
-
Does a lookup for the objects representing the given time interval.
- lookupWithIncompletePartitions(Interval) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- LOW_CORRECTION_THRESHOLD - Static variable in class org.apache.druid.hll.HyperLogLogCollector
- LOWER_CLOSED_UPPER_OPEN - org.apache.druid.query.filter.RangeFilter.RangeType
-
[...)
- LOWER_CLOSED_UPPER_UNBOUNDED - org.apache.druid.query.filter.RangeFilter.RangeType
-
[...∞
- LOWER_DEFAULT - org.apache.druid.java.util.common.granularity.Granularity.Formatter
- LOWER_OPEN_UPPER_CLOSED - org.apache.druid.query.filter.RangeFilter.RangeType
-
(...]
- LOWER_OPEN_UPPER_UNBOUNDED - org.apache.druid.query.filter.RangeFilter.RangeType
-
(...∞
- LOWER_UNBOUNDED_UPPER_CLOSED - org.apache.druid.query.filter.RangeFilter.RangeType
-
-∞...]
- LOWER_UNBOUNDED_UPPER_OPEN - org.apache.druid.query.filter.RangeFilter.RangeType
-
-∞...)
- LowerExtractionFn - Class in org.apache.druid.query.extraction
- LowerExtractionFn(String) - Constructor for class org.apache.druid.query.extraction.LowerExtractionFn
- LowerFunc() - Constructor for class org.apache.druid.math.expr.Function.LowerFunc
- lpad(String, int, String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Returns the string left-padded with the string pad to a length of len characters.
- LpadFunc() - Constructor for class org.apache.druid.math.expr.Function.LpadFunc
- 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
- LT - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- LT - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- LZ4 - org.apache.druid.segment.data.CompressionStrategy
- LZ4Compressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.LZ4Compressor
- LZ4Decompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.LZ4Decompressor
- LZF - org.apache.druid.segment.data.CompressionStrategy
- 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
- macro - Variable in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- 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
- MAGIC - Static variable in class org.apache.druid.frame.file.FrameFileWriter
- majorVersion() - Static method in class org.apache.druid.utils.JvmUtils
-
Returns the major version of the current Java runtime for Java 9 and above.
- make() - Method in interface org.apache.druid.java.util.common.guava.BaseSequence.IteratorMaker
- make(int, int, T) - Static method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- make(Integer, Integer, int, T) - Static method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- make(ArrayList<ColumnWithDirection>) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultNaiveSortMaker
- make(ArrayList<ColumnWithDirection>) - Method in interface org.apache.druid.query.rowsandcols.semantic.NaiveSortMaker
-
Makes the NaiveSorter that will actually do the sort.
- make(AtomicInteger) - Method in interface org.apache.druid.query.rowsandcols.semantic.ColumnSelectorFactoryMaker
- make(AtomicInteger) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultColumnSelectorFactoryMaker
- make(List<String>) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultSortedMatrixMaker
- make(List<String>) - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker
- make(StringTuple, StringTuple, int, T) - Static method in class org.apache.druid.timeline.partition.StringPartitionChunk
- make(ColumnWithDirection...) - Method in interface org.apache.druid.query.rowsandcols.semantic.NaiveSortMaker
- make(T) - Static method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- 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.firstlast.first.DoubleFirstAggregatorFactory
- makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- makeAggregateCombiner() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- 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.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
- makeAlert(String, Object...) - Method in class org.apache.druid.java.util.emitter.EmittingLogger
- makeAlert(Throwable, String, Object...) - Method in class org.apache.druid.java.util.emitter.EmittingLogger
- makeAlwaysFalseWithNullUnknownDimensionMatcher(DimensionSelector, boolean) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Create a matcher that should always return false, except when
includeUnknown
is set, in which case only null values will be matched. - makeAlwaysFalseWithNullUnknownNumericMatcher(BaseNullableColumnValueSelector) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Create a matcher that should always return false, except when
includeUnknown
is set, in which case only null values will be matched. - makeAlwaysFalseWithNullUnknownObjectMatcher(BaseObjectColumnValueSelector<?>) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Create a matcher that should always return false, except when
includeUnknown
is set, in which case only null values will be matched. - makeArrayPredicate(TypeSignature<ValueType>) - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
- makeArrayPredicate(TypeSignature<ValueType>) - Method in class org.apache.druid.query.filter.EqualityFilter.EqualityPredicateFactory
- makeArrayPredicate(TypeSignature<ValueType>) - Method in class org.apache.druid.query.filter.NullFilter.NullPredicateFactory
- makeArrayProcessor(BaseObjectColumnValueSelector<?>, ColumnCapabilities) - Method in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- makeArrayProcessor(BaseObjectColumnValueSelector<?>, ColumnCapabilities) - Method in interface org.apache.druid.segment.ColumnProcessorFactory
- makeArrayProcessor(BaseObjectColumnValueSelector<?>, ColumnCapabilities) - Method in class org.apache.druid.segment.filter.PredicateValueMatcherFactory
- makeArrayProcessor(BaseObjectColumnValueSelector<?>, ColumnCapabilities) - Method in class org.apache.druid.segment.filter.StringConstantValueMatcherFactory
- makeArrayProcessor(ColumnCapabilities, VectorObjectSelector) - Method in class org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- makeArrayProcessor(ColumnCapabilities, VectorObjectSelector) - Method in class org.apache.druid.query.filter.vector.VectorValueMatcherColumnProcessorFactory
- makeArrayProcessor(ColumnCapabilities, VectorObjectSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
- makeArrayProcessor(ColumnCapabilities, VectorObjectSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
-
Called when
TypeSignature.getType()
is ARRAY. - makeAsMap(Class<T>) - Static method in interface org.apache.druid.query.rowsandcols.RowsAndColumns
- makeBasicAuthenticationString(String, String) - Static method in class org.apache.druid.java.util.http.client.Request
- 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 fromQueryMetrics.filterBundle(FilterBundle.BundleInfo)
. - makeBitmapResultFactory(BitmapFactory) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- makeBooleanProcessor(Expr.VectorInputBindingInspector, Expr, Expr, Supplier<LongOutObjectsInFunctionVectorProcessor>, Supplier<LongOutLongsInFunctionVectorValueProcessor>, Supplier<LongOutLongDoubleInFunctionVectorValueProcessor>, Supplier<LongOutDoubleLongInFunctionVectorValueProcessor>, Supplier<LongOutDoublesInFunctionVectorValueProcessor>) - Static method in class org.apache.druid.math.expr.vector.VectorComparisonProcessors
- 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
- makeChildWriteOutMedium() - Method in class org.apache.druid.segment.writeout.OffHeapMemorySegmentWriteOutMedium
- makeChildWriteOutMedium() - Method in class org.apache.druid.segment.writeout.OnHeapMemorySegmentWriteOutMedium
- makeChildWriteOutMedium() - Method in interface org.apache.druid.segment.writeout.SegmentWriteOutMedium
-
Creates a 'child' version of the
SegmentWriteOutMedium
, which can be optionally closed, independent of thisSegmentWriteOutMedium
but otherwise shares the same configuration. - makeChildWriteOutMedium() - Method in class org.apache.druid.segment.writeout.TmpFileSegmentWriteOutMedium
- makeClosingQueryRunner(QueryRunner<T>, Closeable) - Static method in class org.apache.druid.query.QueryRunnerHelper
- makeCollector(ByteBuffer) - Static method in class org.apache.druid.hll.HyperLogLogCollector
-
Create a wrapper object around an HLL sketch contained within a buffer.
- makeCollectorSharingStorage(HyperLogLogCollector) - Static method in class org.apache.druid.hll.HyperLogLogCollector
-
Creates new collector which shares others collector buffer (by using
ByteBuffer.duplicate()
) - makeColumnDescriptor() - Method in class org.apache.druid.segment.AutoTypeColumnMerger
- 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.NestedDataColumnMergerV4
- makeColumnDescriptor() - Method in class org.apache.druid.segment.StringDimensionMergerV9
- makeColumnSelectorFactory(AggregatorFactory, IncrementalIndex.InputRowHolder) - 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
forIndexedTableJoinMatcher
to create selectors. - makeColumnSelectorFactory(VirtualColumns, IncrementalIndex.InputRowHolder, AggregatorFactory) - Static method in class org.apache.druid.segment.incremental.IncrementalIndex
-
Column selector used at ingestion time for inputs to aggregators.
- makeColumnSelectorStrategy(ColumnCapabilities, ColumnValueSelector, String) - Method in class org.apache.druid.query.aggregation.cardinality.types.CardinalityAggregatorColumnSelectorStrategyFactory
- makeColumnSelectorStrategy(ColumnCapabilities, ColumnValueSelector, String) - Method in interface org.apache.druid.query.dimension.ColumnSelectorStrategyFactory
- makeColumnSelectorStrategy(ColumnCapabilities, ColumnValueSelector, String) - Method in class org.apache.druid.query.groupby.epinephelinae.GroupByColumnSelectorStrategyFactory
- makeColumnSelectorStrategy(ColumnCapabilities, ColumnValueSelector, String) - Method in class org.apache.druid.query.topn.types.TopNColumnAggregatesProcessorFactory
- makeColumnValueSelector(String) - Method in class org.apache.druid.frame.processor.MultiColumnSelectorFactory
- makeColumnValueSelector(String) - Method in class org.apache.druid.frame.segment.row.FrameColumnSelectorFactory
- makeColumnValueSelector(String) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultColumnSelectorFactoryMaker.ColumnAccessorBasedColumnSelectorFactory
- makeColumnValueSelector(String) - Method in class org.apache.druid.query.scan.SettableCursorColumnSelectorFactory
-
Create
ColumnValueSelector
for the give column name - 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(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(String) - Method in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
- makeColumnValueSelector(String) - Method in class org.apache.druid.segment.RowBasedColumnSelectorFactory
- makeColumnValueSelector(String) - Method in class org.apache.druid.segment.virtual.VirtualizedColumnSelectorFactory
- makeColumnValueSelector(String, ColumnSelectorFactory) - Method in class org.apache.druid.frame.util.SettableLongVirtualColumn
- makeColumnValueSelector(String, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- makeColumnValueSelector(String, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- makeColumnValueSelector(String, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- makeColumnValueSelector(String, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- makeColumnValueSelector(String, ColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
-
Build a
ColumnValueSelector
corresponding to this virtual column. - 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.virtual.NestedFieldVirtualColumn
- makeColumnValueSelector(String, ColumnSelector, ReadableOffset) - Method in interface org.apache.druid.segment.VirtualColumn
-
Returns similar
ColumnValueSelector
object as returned byVirtualColumn.makeColumnValueSelector(String, ColumnSelectorFactory)
except this method has full access to the underlying column and can potentially provide a more efficient implementation. - makeColumnValueSelector(String, ColumnSelector, ReadableOffset) - Method in class org.apache.druid.segment.VirtualColumns
-
Try to create an optimized value selector directly from a
ColumnSelector
. - makeColumnValueSelector(List<NestedPathPart>, ReadableOffset) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- makeColumnValueSelector(List<NestedPathPart>, ReadableOffset) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Make a
ColumnValueSelector
for a nested field column - makeColumnValueSelector(Memory, ReadableFieldPointer) - Method in class org.apache.druid.frame.field.ComplexFieldReader
- makeColumnValueSelector(Memory, ReadableFieldPointer) - Method in class org.apache.druid.frame.field.DoubleArrayFieldReader
- makeColumnValueSelector(Memory, ReadableFieldPointer) - Method in interface org.apache.druid.frame.field.FieldReader
-
Create a
ColumnValueSelector
backed by some memory and a moveable pointer. - makeColumnValueSelector(Memory, ReadableFieldPointer) - Method in class org.apache.druid.frame.field.FloatArrayFieldReader
- makeColumnValueSelector(Memory, ReadableFieldPointer) - Method in class org.apache.druid.frame.field.LongArrayFieldReader
- makeColumnValueSelector(Memory, ReadableFieldPointer) - Method in class org.apache.druid.frame.field.NumericFieldReader
- makeColumnValueSelector(Memory, ReadableFieldPointer) - Method in class org.apache.druid.frame.field.StringFieldReader
- 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(ReadableOffset) - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader.NumericArrayFrameColumn
- 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
inComplexColumnSerializer
. - 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(ReadableOffset) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- makeColumnValueSelector(ReadableOffset) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- makeColumnValueSelector(ReadableOffset) - Method in class org.apache.druid.segment.nested.ScalarDoubleColumn
- makeColumnValueSelector(ReadableOffset) - Method in class org.apache.druid.segment.nested.ScalarLongColumn
- makeColumnValueSelector(ReadableOffset) - Method in class org.apache.druid.segment.nested.VariantColumn
- 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 class org.apache.druid.segment.AutoTypeColumnIndexer
- makeColumnValueSelector(IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- 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(IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.LongDimensionIndexer
- makeColumnValueSelector(IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- makeComparatorPredicate(RangeFilter.RangeType, Comparator<T>, T, T) - Static method in class org.apache.druid.query.filter.RangeFilter
- makeComparisonProcessor(Expr.VectorInputBindingInspector, Expr, Expr, Supplier<LongOutObjectsInFunctionVectorProcessor>, Supplier<LongOutLongsInFunctionVectorValueProcessor>, Supplier<DoubleOutLongDoubleInFunctionVectorValueProcessor>, Supplier<DoubleOutDoubleLongInFunctionVectorValueProcessor>, Supplier<DoubleOutDoublesInFunctionVectorValueProcessor>) - Static method in class org.apache.druid.math.expr.vector.VectorComparisonProcessors
-
Deprecated.
- makeComparisonWidget(Frame, List<KeyColumn>) - Method in class org.apache.druid.frame.read.FrameReader
-
Create a
FrameComparisonWidget
for the given frame. - makeComplexProcessor(BaseObjectColumnValueSelector<?>) - Method in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- 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.PredicateValueMatcherFactory
- makeComplexProcessor(BaseObjectColumnValueSelector<?>) - Method in class org.apache.druid.segment.filter.StringConstantValueMatcherFactory
- makeContinuousUniform(String, ValueType, boolean, int, Double, double, double) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- makeCursor(Frame, FrameReader) - Static method in class org.apache.druid.frame.processor.FrameProcessors
-
Returns a
FrameCursor
for the providedFrame
, allowing both sequential and random access. - makeCursor(Frame, FrameReader, VirtualColumns) - Static method in class org.apache.druid.frame.processor.FrameProcessors
-
Returns a
FrameCursor
for the providedFrame
andVirtualColumns
, allowing both sequential and random access. - makeCursorBasedQuery(StorageAdapter, List<Interval>, Filter, VirtualColumns, boolean, Granularity, Function<Cursor, Result<T>>, QueryMetrics<?>) - Static method in class org.apache.druid.query.QueryRunnerHelper
- makeCursorFactory(Frame) - Method in class org.apache.druid.frame.read.FrameReader
-
Create a
CursorFactory
for the given frame. - makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in class org.apache.druid.frame.segment.columnar.FrameCursorFactory
- makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in class org.apache.druid.frame.segment.row.FrameCursorFactory
- 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.FilteredStorageAdapter
- 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
- makeCursors(Filter, Interval, VirtualColumns, Granularity, boolean, QueryMetrics<?>) - Method in class org.apache.druid.segment.UnnestStorageAdapter
- makeDefaultCapabilitiesFromValueType(ColumnType) - Static method in class org.apache.druid.segment.incremental.IncrementalIndex
- makeDictionaryWriter(String) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- makeDictionaryWriter(String) - Method in class org.apache.druid.segment.StringDimensionMergerV9
- makeDimensionProcessor(DimensionSelector, boolean) - Method in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- 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.PredicateValueMatcherFactory
- makeDimensionProcessor(DimensionSelector, boolean) - Method in class org.apache.druid.segment.filter.StringConstantValueMatcherFactory
- makeDimensionSelector(List<NestedPathPart>, ReadableOffset, ExtractionFn) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- makeDimensionSelector(List<NestedPathPart>, ReadableOffset, ExtractionFn) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Make a
DimensionSelector
for a nested field column - makeDimensionSelector(Memory, ReadableFieldPointer, ExtractionFn) - Method in class org.apache.druid.frame.field.ComplexFieldReader
- makeDimensionSelector(Memory, ReadableFieldPointer, ExtractionFn) - Method in interface org.apache.druid.frame.field.FieldReader
-
Create a
DimensionSelector
backed by some memory and a moveable pointer. - makeDimensionSelector(Memory, ReadableFieldPointer, ExtractionFn) - Method in class org.apache.druid.frame.field.NumericArrayFieldReader
- makeDimensionSelector(Memory, ReadableFieldPointer, ExtractionFn) - Method in class org.apache.druid.frame.field.NumericFieldReader
- makeDimensionSelector(Memory, ReadableFieldPointer, ExtractionFn) - Method in class org.apache.druid.frame.field.StringFieldReader
- makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.frame.processor.MultiColumnSelectorFactory
- makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.frame.segment.row.FrameColumnSelectorFactory
- makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultColumnSelectorFactoryMaker.ColumnAccessorBasedColumnSelectorFactory
- makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.query.scan.SettableCursorColumnSelectorFactory
- makeDimensionSelector(DimensionSpec) - Method in interface org.apache.druid.segment.ColumnSelectorFactory
- 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) - Method in class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
- makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.RowBasedColumnSelectorFactory
- makeDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.virtual.VirtualizedColumnSelectorFactory
- makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in class org.apache.druid.frame.util.SettableLongVirtualColumn
- makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- makeDimensionSelector(DimensionSpec, ColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
-
Build a selector corresponding to this virtual column.
- 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.virtual.NestedFieldVirtualColumn
- makeDimensionSelector(DimensionSpec, ColumnSelector, ReadableOffset) - Method in interface org.apache.druid.segment.VirtualColumn
-
Returns similar
DimensionSelector
object as returned byVirtualColumn.makeDimensionSelector(DimensionSpec, ColumnSelectorFactory)
except this method has full access to the underlying column and can potentially provide a more efficient implementation. - makeDimensionSelector(DimensionSpec, ColumnSelector, ReadableOffset) - Method in class org.apache.druid.segment.VirtualColumns
-
Try to create an optimized dimension (string) selector directly from a
ColumnSelector
. - makeDimensionSelector(DimensionSpec, IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- 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, IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.LongDimensionIndexer
- makeDimensionSelector(DimensionSpec, IncrementalIndexRowHolder, IncrementalIndex.DimensionDesc) - Method in class org.apache.druid.segment.NestedDataColumnIndexerV4
- 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 aColumnValueSelector
created byExpressionSelectors.makeExprEvalSelector(ColumnSelectorFactory, Expr)
as appropriate - makeDimensionSelector(ReadableOffset, ExtractionFn) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
- makeDimensionSelector(ReadableOffset, ExtractionFn) - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- makeDimensionSelector(ReadableOffset, ExtractionFn) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- makeDimensionSelector(ReadableOffset, ExtractionFn) - Method in class org.apache.druid.segment.nested.VariantColumn
- makeDimFile(File, String) - Static method in class org.apache.druid.segment.IndexIO
- makeDimValAggregateStore(PooledTopNAlgorithm.PooledTopNParams) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
- makeDimValAggregateStore(TopNParams) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
- makeDimValAggregateStore(TopNParams) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
- makeDimValAggregateStore(Parameters) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
- 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.HeapBasedTopNAlgorithm
- makeDimValSelector(TopNParams, int, int) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
- makeDimValSelector(Parameters, int, int) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
- makeDiscreteUniform(String, ValueType, boolean, int, Double, int, int) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- makeDoubleMathProcessor(Expr.VectorInputBindingInspector, Expr, Supplier<DoubleOutLongInFunctionVectorValueProcessor>, Supplier<DoubleOutDoubleInFunctionVectorValueProcessor>) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
-
Make a 1 argument math processor with the following type rules long -> double double -> double
- makeDoubleMathProcessor(Expr.VectorInputBindingInspector, Expr, Expr, Supplier<DoubleOutLongsInFunctionVectorValueProcessor>, Supplier<DoubleOutLongDoubleInFunctionVectorValueProcessor>, Supplier<DoubleOutDoubleLongInFunctionVectorValueProcessor>, Supplier<DoubleOutDoublesInFunctionVectorValueProcessor>) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
-
Make a 2 argument, math processor with the following type rules long, long -> double long, double -> double double, long -> double double, double -> double
- makeDoublePredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
- makeDoublePredicate() - Method in class org.apache.druid.query.filter.EqualityFilter.EqualityPredicateFactory
- 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.NullFilter.NullPredicateFactory
- makeDoublePredicate() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
- makeDoublePredicate() - Method in class org.apache.druid.query.filter.StringPredicateDruidPredicateFactory
- makeDoublePredicate() - Method in class org.apache.druid.query.filter.TypedInFilter.PredicateFactory
- makeDoublePredicate(RangeFilter.RangeType, double, double) - Static method in class org.apache.druid.query.filter.RangeFilter
- makeDoubleProcessor(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- 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.PredicateValueMatcherFactory
- makeDoubleProcessor(BaseDoubleColumnValueSelector) - Method in class org.apache.druid.segment.filter.StringConstantValueMatcherFactory
- makeDoubleProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- 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(ColumnCapabilities, VectorValueSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
-
Called when
TypeSignature.getType()
is DOUBLE. - makeDoubleValueMatcher(BaseDoubleColumnValueSelector, double) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Creates a constant-based
ValueMatcher
for a double-typed selector. - 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. - makeEmitter(ObjectMapper, Lifecycle) - Method in class org.apache.druid.java.util.emitter.factory.LoggingEmitterFactory
- makeEmitter(ObjectMapper, AsyncHttpClient, Lifecycle) - Method in interface org.apache.druid.java.util.emitter.factory.EmitterFactory
- makeEmitter(ObjectMapper, AsyncHttpClient, Lifecycle) - Method in class org.apache.druid.java.util.emitter.factory.HttpEmitterFactory
- makeEmitter(ObjectMapper, AsyncHttpClient, Lifecycle) - Method in class org.apache.druid.java.util.emitter.factory.LoggingEmitterFactory
- makeEmitter(ObjectMapper, AsyncHttpClient, Lifecycle) - Method in class org.apache.druid.java.util.emitter.factory.NoopEmitterFactory
- makeEmitter(ObjectMapper, AsyncHttpClient, Lifecycle) - Method in class org.apache.druid.java.util.emitter.factory.ParametrizedUriEmitterFactory
- makeEmitter(Lifecycle) - Method in class org.apache.druid.java.util.emitter.factory.NoopEmitterFactory
- 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
- makeEmptyVersionedByteArray() - Static method in class org.apache.druid.hll.HyperLogLogCollector
- 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
- makeException(DruidException.DruidExceptionBuilder) - Method in class org.apache.druid.error.BaseFailure
- makeException(DruidException.DruidExceptionBuilder) - Method in class org.apache.druid.error.DruidException.Failure
- makeException(DruidException.DruidExceptionBuilder) - Method in class org.apache.druid.error.InvalidSqlInput
- makeException(DruidException.DruidExceptionBuilder) - Method in class org.apache.druid.error.QueryExceptionCompat
- makeExprEvalSelector(ColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
-
Makes a ColumnValueSelector whose getObject method returns an
ExprEval
. - makeFactory(Properties) - Method in class org.apache.druid.guice.ConfigModule
- makeFilterBundle(ColumnIndexSelector, BitmapResultFactory<T>, int, int, boolean) - Method in interface org.apache.druid.query.filter.Filter
-
Compute indexes and build a container
FilterBundle
to be used duringCursor
orVectorCursor
creation, combining the computed outputs ofFilter.getBitmapColumnIndex(ColumnIndexSelector)
as well as references toFilter.makeMatcher(ColumnSelectorFactory)
andFilter.makeVectorMatcher(VectorColumnSelectorFactory)
. - makeFilterBundle(ColumnIndexSelector, BitmapResultFactory<T>, int, int, boolean) - Method in class org.apache.druid.segment.filter.AndFilter
- makeFilterBundle(ColumnIndexSelector, BitmapResultFactory<T>, int, int, boolean) - Method in class org.apache.druid.segment.filter.OrFilter
- makeFloatPredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
- makeFloatPredicate() - Method in class org.apache.druid.query.filter.EqualityFilter.EqualityPredicateFactory
- 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.NullFilter.NullPredicateFactory
- makeFloatPredicate() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
- makeFloatPredicate() - Method in class org.apache.druid.query.filter.StringPredicateDruidPredicateFactory
- makeFloatPredicate() - Method in class org.apache.druid.query.filter.TypedInFilter.PredicateFactory
- makeFloatProcessor(BaseFloatColumnValueSelector) - Method in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- 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.PredicateValueMatcherFactory
- makeFloatProcessor(BaseFloatColumnValueSelector) - Method in class org.apache.druid.segment.filter.StringConstantValueMatcherFactory
- makeFloatProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- 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(ColumnCapabilities, VectorValueSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
-
Called when
TypeSignature.getType()
is FLOAT. - makeFloatValueMatcher(BaseFloatColumnValueSelector, float) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Creates a constant-based
ValueMatcher
for a float-typed selector. - 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. - makeForSingleDimension(String, String, int, T) - Static method in class org.apache.druid.timeline.partition.StringPartitionChunk
- makeFrameWriterFactory(FrameType, MemoryAllocatorFactory, RowSignature, List<KeyColumn>) - Static method in class org.apache.druid.frame.write.FrameWriters
-
Creates a
FrameWriterFactory
. - 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<DimensionSpec>, 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
- makeIndexer(boolean) - 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(boolean) - Method in class org.apache.druid.segment.DoubleDimensionHandler
- makeIndexer(boolean) - Method in class org.apache.druid.segment.FloatDimensionHandler
- makeIndexer(boolean) - Method in class org.apache.druid.segment.LongDimensionHandler
- makeIndexer(boolean) - Method in class org.apache.druid.segment.NestedCommonFormatColumnHandler
- makeIndexer(boolean) - Method in class org.apache.druid.segment.NestedDataColumnHandlerV4
- makeIndexer(boolean) - Method in class org.apache.druid.segment.StringDimensionHandler
- makeIndexPathName(DataSegment, String) - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
- makeIngestionRowMetrics(long, long, long, long) - Static method in class org.apache.druid.indexer.TaskMetricsUtils
- makeInitParams(ColumnSelectorPlus<TopNColumnAggregatesProcessor>, Cursor) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
- makeInitParams(ColumnSelectorPlus<TopNColumnAggregatesProcessor>, Cursor) - Method in interface org.apache.druid.query.topn.TopNAlgorithm
- makeInitParams(ColumnSelectorPlus, Cursor) - Method in class org.apache.druid.query.topn.AggregateTopNMetricFirstAlgorithm
- makeInitParams(ColumnSelectorPlus, Cursor) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
- makeInitParams(ColumnSelectorPlus, Cursor) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
- makeJoinCursor(Cursor, JoinableClause, boolean, Closer) - Static method in class org.apache.druid.segment.join.HashJoinEngine
-
Creates a cursor that represents the join of {@param leftCursor} with {@param joinableClause}.
- 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
- makeJsonPathExtractor(String) - Method in class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- makeJsonPathExtractor(String) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
-
Create a "field" extractor for
JsonPath
expressions - makeJsonQueryExtractor(String) - Method in class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- makeJsonQueryExtractor(String) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
-
Create a "field" extractor for 'jq' expressions
- makeJsonTreeExtractor(List<String>) - Method in class org.apache.druid.java.util.common.parsers.JSONFlattenerMaker
- makeJsonTreeExtractor(List<String>) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
-
Create a "field" extractor for nested json expressions
- makeLaneErrorMessage(String, int) - Static method in exception org.apache.druid.query.QueryCapacityExceededException
- makeLatestCollector() - Static method in class org.apache.druid.hll.HyperLogLogCollector
- 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
- makeLoadSpec(URI) - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
- makeLoadSpec(URI) - Method in class org.apache.druid.segment.loading.NoopDataSegmentPusher
- makeLongMathProcessor(Expr.VectorInputBindingInspector, Expr, Supplier<LongOutLongInFunctionVectorValueProcessor>, Supplier<LongOutDoubleInFunctionVectorValueProcessor>) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
-
Make a 1 argument math processor with the following type rules long -> long double -> long
- makeLongMathProcessor(Expr.VectorInputBindingInspector, Expr, Expr, Supplier<LongOutLongsInFunctionVectorValueProcessor>, Supplier<LongOutLongDoubleInFunctionVectorValueProcessor>, Supplier<LongOutDoubleLongInFunctionVectorValueProcessor>, Supplier<LongOutDoublesInFunctionVectorValueProcessor>) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
-
Make a 2 argument, math processor with the following type rules long, long -> long long, double -> long double, long -> long double, double -> long
- makeLongPredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
- makeLongPredicate() - Method in class org.apache.druid.query.filter.EqualityFilter.EqualityPredicateFactory
- 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.NullFilter.NullPredicateFactory
- makeLongPredicate() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
- makeLongPredicate() - Method in class org.apache.druid.query.filter.StringPredicateDruidPredicateFactory
- makeLongPredicate() - Method in class org.apache.druid.query.filter.TypedInFilter.PredicateFactory
- makeLongPredicate(RangeFilter.RangeType, long, long) - Static method in class org.apache.druid.query.filter.RangeFilter
- makeLongProcessor(BaseLongColumnValueSelector) - Method in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- 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.PredicateValueMatcherFactory
- makeLongProcessor(BaseLongColumnValueSelector) - Method in class org.apache.druid.segment.filter.StringConstantValueMatcherFactory
- makeLongProcessor(ColumnCapabilities, VectorValueSelector) - Method in class org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- 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(ColumnCapabilities, VectorValueSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
-
Called when
TypeSignature.getType()
is LONG. - makeLongValueMatcher(BaseLongColumnValueSelector, long) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Creates a constant-based
ValueMatcher
for a long-typed selector. - makeLongValueMatcher(BaseLongColumnValueSelector, String) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Creates a constant-based
ValueMatcher
for a long-typed selector. - makeLongValueMatcher(BaseLongColumnValueSelector, DruidPredicateFactory) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
Creates a predicate-based
ValueMatcher
for a long-typed selector. - makeMatcher(Object, ColumnType) - Method in class org.apache.druid.query.filter.vector.ArrayVectorValueMatcher
- makeMatcher(Object, ColumnType) - Method in class org.apache.druid.query.filter.vector.DoubleVectorValueMatcher
- makeMatcher(Object, ColumnType) - Method in class org.apache.druid.query.filter.vector.FloatVectorValueMatcher
- makeMatcher(Object, ColumnType) - Method in class org.apache.druid.query.filter.vector.LongVectorValueMatcher
- makeMatcher(Object, ColumnType) - Method in class org.apache.druid.query.filter.vector.MultiValueStringVectorValueMatcher
- makeMatcher(Object, ColumnType) - Method in class org.apache.druid.query.filter.vector.ObjectVectorValueMatcher
- makeMatcher(Object, ColumnType) - Method in class org.apache.druid.query.filter.vector.SingleValueStringVectorValueMatcher
- makeMatcher(Object, ColumnType) - Method in class org.apache.druid.query.filter.vector.StringObjectVectorValueMatcher
- makeMatcher(Object, ColumnType) - Method in interface org.apache.druid.query.filter.vector.VectorValueMatcherFactory
-
Specialized value matcher for equality used by
EqualityFilter
. - makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.ArrayVectorValueMatcher
- makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.DoubleVectorValueMatcher
- makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.FloatVectorValueMatcher
- makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.LongVectorValueMatcher
- makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.MultiValueStringVectorValueMatcher
- makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.ObjectVectorValueMatcher
- makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.SingleValueStringVectorValueMatcher
- makeMatcher(String) - Method in class org.apache.druid.query.filter.vector.StringObjectVectorValueMatcher
- makeMatcher(String) - Method in interface org.apache.druid.query.filter.vector.VectorValueMatcherFactory
-
Specialized value matcher for string equality used by
SelectorDimFilter
- makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.ArrayVectorValueMatcher
- makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.DoubleVectorValueMatcher
- makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.FloatVectorValueMatcher
- makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.LongVectorValueMatcher
- makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.MultiValueStringVectorValueMatcher
- makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.ObjectVectorValueMatcher
- makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.SingleValueStringVectorValueMatcher
- makeMatcher(DruidPredicateFactory) - Method in class org.apache.druid.query.filter.vector.StringObjectVectorValueMatcher
- makeMatcher(DruidPredicateFactory) - Method in interface org.apache.druid.query.filter.vector.VectorValueMatcherFactory
- makeMatcher(ValueMatcher[]) - Static method in class org.apache.druid.segment.filter.AndFilter
- makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.query.filter.EqualityFilter
- 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(ColumnSelectorFactory) - Method in class org.apache.druid.query.filter.NullFilter
- makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.query.filter.RangeFilter
- makeMatcher(ColumnSelectorFactory) - Method in class org.apache.druid.query.filter.TypedInFilter
- makeMatcher(ColumnSelectorFactory) - 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.IsBooleanFilter
- 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(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
- makeMathProcessor(Expr.VectorInputBindingInspector, Expr, Supplier<LongOutLongInFunctionVectorValueProcessor>, Supplier<DoubleOutDoubleInFunctionVectorValueProcessor>) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
-
Make a 1 argument math processor with the following type rules long -> long double -> double
- makeMathProcessor(Expr.VectorInputBindingInspector, Expr, Expr, Supplier<LongOutLongsInFunctionVectorValueProcessor>, Supplier<DoubleOutLongDoubleInFunctionVectorValueProcessor>, Supplier<DoubleOutDoubleLongInFunctionVectorValueProcessor>, Supplier<DoubleOutDoublesInFunctionVectorValueProcessor>) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
-
Make a 2 argument, math processor with the following type rules long, long -> long long, double -> double double, long -> double double, double -> double
- 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.NestedCommonFormatColumnHandler
- makeMerger(IndexSpec, SegmentWriteOutMedium, ColumnCapabilities, ProgressIndicator, Closer) - Method in class org.apache.druid.segment.NestedDataColumnHandlerV4
- 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() - Method in class org.apache.druid.query.DefaultGenericQueryMetricsFactory
- makeMetrics() - Method in interface org.apache.druid.query.GenericQueryMetricsFactory
-
Creates a
QueryMetrics
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() - Method in class org.apache.druid.query.timeseries.DefaultTimeseriesQueryMetricsFactory
- makeMetrics() - Method in interface org.apache.druid.query.timeseries.TimeseriesQueryMetricsFactory
- makeMetrics() - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetricsFactory
- makeMetrics() - Method in interface org.apache.druid.query.topn.TopNQueryMetricsFactory
- makeMetrics(DataSourceMetadataQuery) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
- makeMetrics(GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- makeMetrics(SegmentMetadataQuery) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
- makeMetrics(WindowOperatorQuery) - Method in class org.apache.druid.query.operator.WindowOperatorQueryQueryToolChest
- 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(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(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
- makeMetrics(TopNQuery) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
- 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. - makeMissingColumnNullIndex(DruidPredicateMatch, ColumnIndexSelector) - Static method in class org.apache.druid.segment.filter.Filters
- makeMultiValueDimensionProcessor(ColumnCapabilities, MultiValueDimensionVectorSelector) - Method in class org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- 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
-
Called only if
TypeSignature.getType()
is STRING and the underlying column may have multiple values per row. - makeMultiValueDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
- makeMultiValueDimensionSelector(DimensionSpec) - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
-
Returns a dictionary encoded, string-typed, multi-value-per-row column 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
. - makeMultiValueDimensionVectorSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
-
Create a multi value dimension vector (string) selector.
- makeMultiValueDimensionVectorSelector(ReadableVectorOffset) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
- makeMultiValueDimensionVectorSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- makeMultiValueDimensionVectorSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- makeMultiValueDimensionVectorSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.VariantColumn
- makeMultiValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) - Method in interface org.apache.druid.segment.VirtualColumn
-
Returns similar
SingleValueDimensionVectorSelector
object as returned byVirtualColumn.makeSingleValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset)
except this method has full access to the underlying column and can potentially provide a more efficient implementation. - makeMultiValueVectorDimensionSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- makeMultiValueVectorDimensionSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
-
Build a
MultiValueDimensionVectorSelector
corresponding to this virtual column. - makeNewSettableColumnValueSelector() - Method in class org.apache.druid.frame.read.columnar.ColumnPlus
- 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.NestedCommonFormatColumnHandler
- makeNewSettableEncodedValueSelector() - Method in class org.apache.druid.segment.NestedDataColumnHandlerV4
- 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
- makeNullableNumericSupplier(ColumnValueSelector, Supplier<T>) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
-
Wraps a
ColumnValueSelector
and uses it to supply numeric values in a null-aware way. - makeNullHandlingBufferComparatorForNumericData(int, Grouper.BufferComparator) - Static method in class org.apache.druid.query.groupby.epinephelinae.GrouperBufferComparatorUtils
- makeNumericWrappingDimensionSelector(ValueType, ColumnValueSelector<?>, ExtractionFn) - Static method in class org.apache.druid.segment.column.ValueTypes
- makeObject(byte[], int, int) - Method in class org.apache.druid.data.input.impl.FastLineIterator.Bytes
- makeObject(byte[], int, int) - Method in class org.apache.druid.data.input.impl.FastLineIterator
- makeObject(byte[], int, int) - Method in class org.apache.druid.data.input.impl.FastLineIterator.Strings
- makeObjectPredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
-
Object predicate is currently only used by vectorized matchers for non-string object selectors.
- makeObjectPredicate() - Method in class org.apache.druid.query.filter.EqualityFilter.EqualityPredicateFactory
- makeObjectPredicate() - Method in class org.apache.druid.query.filter.NullFilter.NullPredicateFactory
- makeObjectProcessor(ColumnCapabilities, VectorObjectSelector) - Method in class org.apache.druid.query.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- makeObjectProcessor(ColumnCapabilities, VectorObjectSelector) - Method in class org.apache.druid.query.filter.vector.VectorValueMatcherColumnProcessorFactory
- makeObjectProcessor(ColumnCapabilities, VectorObjectSelector) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
- makeObjectProcessor(ColumnCapabilities, VectorObjectSelector) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
-
Called when
TypeSignature.getType()
is COMPLEX. - 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.
- makeParser() - Method in class org.apache.druid.data.input.impl.CSVParseSpec
- makeParser() - Method in class org.apache.druid.data.input.impl.DelimitedParseSpec
- makeParser() - Method in class org.apache.druid.data.input.impl.JavaScriptParseSpec
- makeParser() - Method in class org.apache.druid.data.input.impl.JSONLowercaseParseSpec
-
Deprecated.
- makeParser() - Method in class org.apache.druid.data.input.impl.JSONParseSpec
- makeParser() - Method in class org.apache.druid.data.input.impl.ParseSpec
-
Deprecated.
- makeParser() - Method in class org.apache.druid.data.input.impl.RegexParseSpec
- makeParser() - Method in class org.apache.druid.data.input.impl.TimeAndDimsParseSpec
- makePeekingComparator() - Static method in class org.apache.druid.segment.DictionaryMergingIterator
- makePeekingComparator() - Static method in class org.apache.druid.segment.SimpleDictionaryMergingIterator
- makePostComputeManipulatorFn(GroupByQuery, MetricManipulationFn) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- makePostComputeManipulatorFn(TimeseriesQuery, MetricManipulationFn) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
- makePostComputeManipulatorFn(TopNQuery, MetricManipulationFn) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
- makePostComputeManipulatorFn(QueryType, MetricManipulationFn) - Method in class org.apache.druid.query.QueryToolChest
-
This manipulator functions primary purpose is to conduct finalization of aggregator values.
- 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(WindowOperatorQuery, MetricManipulationFn) - Method in class org.apache.druid.query.operator.WindowOperatorQueryQueryToolChest
- 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
- 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.
- makePredicateIndex(String, ColumnIndexSelector, DruidPredicateFactory) - Static method in class org.apache.druid.segment.filter.Filters
- makePredicateMatchingSet(DimensionSelector, DruidObjectPredicate<String>, boolean) - 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(Expr, ColumnType, ColumnProcessorFactory<T>, ColumnSelectorFactory) - Static method in class org.apache.druid.segment.ColumnProcessors
-
Make a processor for a particular expression.
- makeProcessor(DimensionSpec, ColumnProcessorFactory<T>, ColumnSelectorFactory) - Static method in class org.apache.druid.segment.ColumnProcessors
-
Make a processor for a particular
DimensionSpec
. - 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
- makeRowMemorySupplier(ColumnSelectorFactory, RowSignature) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
-
Returns a direct row memory supplier if
FrameReaderUtils.mayBeAbleToSelectRowMemory(org.apache.druid.segment.ColumnSelectorFactory)
, otherwise returns null. - makeSegmentDescriptor(String) - Method in class org.apache.druid.segment.generator.GeneratorSchemaInfo
- 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.aggregation.cardinality.vector.CardinalityVectorProcessorFactory
- 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
-
Called only if
TypeSignature.getType()
is STRING and the underlying column always has a single value per row. - makeSingleValueDimensionSelector(DimensionSpec) - Method in class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
- makeSingleValueDimensionSelector(DimensionSpec) - Method in interface org.apache.druid.segment.vector.VectorColumnSelectorFactory
-
Returns a dictionary encoded, string-typed, single-value-per-row column selector.
- makeSingleValueDimensionVectorSelector(List<NestedPathPart>, ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- makeSingleValueDimensionVectorSelector(List<NestedPathPart>, ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Make a
SingleValueDimensionVectorSelector
for a nested field column - 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
. - makeSingleValueDimensionVectorSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
-
Create a single value dimension vector (string) selector.
- makeSingleValueDimensionVectorSelector(ReadableVectorOffset) - Method in interface org.apache.druid.segment.column.DictionaryEncodedColumn
- makeSingleValueDimensionVectorSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- makeSingleValueDimensionVectorSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- makeSingleValueDimensionVectorSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.VariantColumn
- makeSingleValueDimensionVectorSelector(VectorColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionVectorSelectors
- makeSingleValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- makeSingleValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset) - Method in interface org.apache.druid.segment.VirtualColumn
-
Returns similar
SingleValueDimensionVectorSelector
object as returned byVirtualColumn.makeSingleValueVectorDimensionSelector(DimensionSpec, ColumnSelector, ReadableVectorOffset)
except this method has full access to the underlying column and can potentially provide a more efficient implementation. - makeSingleValueVectorDimensionSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- makeSingleValueVectorDimensionSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- makeSingleValueVectorDimensionSelector(DimensionSpec, VectorColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
-
Build a
SingleValueDimensionVectorSelector
corresponding to this virtual column. - makeSourceIterator(InputStream) - Method in class org.apache.druid.data.input.TextReader.Bytes
- makeSourceIterator(InputStream) - Method in class org.apache.druid.data.input.TextReader
- makeSourceIterator(InputStream) - Method in class org.apache.druid.data.input.TextReader.Strings
- makeStartupInjector() - Static method in class org.apache.druid.guice.GuiceInjectors
- makeStartupInjectorWithModules(Iterable<? extends Module>) - Static method in class org.apache.druid.guice.GuiceInjectors
- makeStringColumnValueSelector(ColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionSelectors
- makeStringPredicate() - Method in interface org.apache.druid.query.filter.DruidPredicateFactory
- makeStringPredicate() - Method in class org.apache.druid.query.filter.EqualityFilter.EqualityPredicateFactory
- 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.NullFilter.NullPredicateFactory
- makeStringPredicate() - Method in class org.apache.druid.query.filter.SelectorPredicateFactory
- makeStringPredicate() - Method in class org.apache.druid.query.filter.StringPredicateDruidPredicateFactory
- makeStringPredicate() - Method in class org.apache.druid.query.filter.TypedInFilter.PredicateFactory
- 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. - makeSymmetricalProcessor(Expr.VectorInputBindingInspector, Expr, Expr, Supplier<ExprVectorProcessor<?>>, Supplier<ExprVectorProcessor<?>>, Supplier<ExprVectorProcessor<?>>) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Make a 2 argument, symmetrical processor where both argments must be the same input type and produce the same output type long, long -> long double, double -> double string, string -> string
- makeThread(String, Runnable, boolean) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- makeThreadFactory(String) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- makeThreadFactory(String, Integer) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- makeTimeFile(File, ByteOrder) - Static method in class org.apache.druid.segment.IndexIO
- makeTotalErrorMessage(int) - Static method in exception org.apache.druid.query.QueryCapacityExceededException
- makeURL(String) - Method in class org.apache.druid.indexer.TaskLocation
- makeValueMatcher(String) - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
- makeValueMatcher(String) - Method in class org.apache.druid.segment.ConstantDimensionSelector
- makeValueMatcher(String) - Method in class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- makeValueMatcher(String) - Method in interface org.apache.druid.segment.DimensionSelector
- makeValueMatcher(String) - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
- makeValueMatcher(String) - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
- makeValueMatcher(String) - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
- makeValueMatcher(String) - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
- makeValueMatcher(String) - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
- makeValueMatcher(String) - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- makeValueMatcher(List<Supplier<String[]>>) - Static method in class org.apache.druid.segment.filter.ColumnComparisonFilter
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.ConstantDimensionSelector
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- makeValueMatcher(DruidPredicateFactory) - Method in interface org.apache.druid.segment.DimensionSelector
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.join.PossiblyNullDimensionSelector
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.join.table.IndexedTableDimensionSelector
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.selector.settable.SettableDimensionValueSelector
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.SingleScanTimeDimensionSelector
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.virtual.ExpressionMultiValueDimensionSelector
- makeValueMatcher(DruidPredicateFactory) - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- makeValueMatcher(ColumnSelectorFactory, String, DruidPredicateFactory) - Static method in class org.apache.druid.segment.filter.Filters
-
Create a ValueMatcher that applies a predicate to row values.
- makeValueMatcherGeneric(DimensionSelector, String) - Static method in class org.apache.druid.segment.DimensionSelectorUtils
-
Generic implementation of
DimensionSelector.makeValueMatcher(String)
, usesDimensionSelector.getRow()
of the givenDimensionSelector
. - makeValueMatcherGeneric(DimensionSelector, DruidPredicateFactory) - Static method in class org.apache.druid.segment.DimensionSelectorUtils
-
Generic implementation of
DimensionSelector.makeValueMatcher(DruidPredicateFactory)
, usesDimensionSelector.getRow()
of the givenDimensionSelector
. - 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 class org.apache.druid.frame.segment.columnar.FrameCursorFactory
- makeVectorCursor(Filter, Interval, VirtualColumns, boolean, int, QueryMetrics<?>) - Method in class org.apache.druid.frame.segment.FrameStorageAdapter
- 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.join.HashJoinSegmentStorageAdapter
- makeVectorCursor(Filter, Interval, VirtualColumns, boolean, int, QueryMetrics<?>) - Method in class org.apache.druid.segment.QueryableIndexStorageAdapter
- makeVectorMatcher(VectorValueMatcher[]) - Static method in class org.apache.druid.segment.filter.AndFilter
- makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.filter.EqualityFilter
- 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.query.filter.NullFilter
- makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.filter.RangeFilter
- makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.query.filter.TypedInFilter
- 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.ExpressionFilter
- makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.FalseFilter
- makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.IsBooleanFilter
- makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.JavaScriptFilter
- 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.SpatialFilter
- makeVectorMatcher(VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.filter.TrueFilter
- makeVectorObjectSelector(String, ColumnSelector, ReadableVectorOffset) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- makeVectorObjectSelector(String, ColumnSelector, ReadableVectorOffset) - Method in interface org.apache.druid.segment.VirtualColumn
-
Returns similar
VectorObjectSelector
object as returned byVirtualColumn.makeVectorObjectSelector(String, VectorColumnSelectorFactory)
except this method has full access to the underlying column and can potentially provide a more efficient implementation. - 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 toVirtualColumns.makeVectorObjectSelector(String, VectorColumnSelectorFactory)
instead. - makeVectorObjectSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- makeVectorObjectSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- makeVectorObjectSelector(String, VectorColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
-
Build a
VectorObjectSelector
corresponding to this virtual column. - makeVectorObjectSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
-
Create a column vector object selector.
- makeVectorObjectSelector(List<NestedPathPart>, ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- makeVectorObjectSelector(List<NestedPathPart>, ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Make a
VectorObjectSelector
for a nested field column - makeVectorObjectSelector(ReadableVectorOffset) - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader.NumericArrayFrameColumn
- 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.StringUtf8DictionaryEncodedColumn
- makeVectorObjectSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.column.UnknownTypeComplexColumn
- makeVectorObjectSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- makeVectorObjectSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- makeVectorObjectSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.VariantColumn
- makeVectorObjectSelector(VectorColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionVectorSelectors
- makeVectorProcessor(String, VectorColumnProcessorFactory<T>, VectorColumnSelectorFactory) - Static method in class org.apache.druid.segment.ColumnProcessors
-
Make a processor for a particular named column.
- makeVectorProcessor(DimensionSpec, VectorColumnProcessorFactory<T>, VectorColumnSelectorFactory) - Static method in class org.apache.druid.segment.ColumnProcessors
-
Make a processor for a particular
DimensionSpec
. - makeVectorValueSelector(String, ColumnSelector, ReadableVectorOffset) - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- makeVectorValueSelector(String, ColumnSelector, ReadableVectorOffset) - Method in interface org.apache.druid.segment.VirtualColumn
-
Returns similar
VectorValueSelector
object as returned byVirtualColumn.makeVectorValueSelector(String, VectorColumnSelectorFactory)
except this method has full access to the underlying column and can potentially provide a more efficient implementation. - makeVectorValueSelector(String, ColumnSelector, ReadableVectorOffset) - Method in class org.apache.druid.segment.VirtualColumns
-
Try to create an optimized vector value selector directly from a
ColumnSelector
. - makeVectorValueSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- makeVectorValueSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- makeVectorValueSelector(String, VectorColumnSelectorFactory) - Method in interface org.apache.druid.segment.VirtualColumn
-
Build a
VectorValueSelector
corresponding to this virtual column. - makeVectorValueSelector(String, VectorColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
-
Create a column vector value selector.
- makeVectorValueSelector(List<NestedPathPart>, ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- makeVectorValueSelector(List<NestedPathPart>, ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.NestedDataComplexColumn
-
Make a
VectorValueSelector
for a nested field column - 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) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- makeVectorValueSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- makeVectorValueSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.ScalarDoubleColumn
- makeVectorValueSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.ScalarLongColumn
- makeVectorValueSelector(ReadableVectorOffset) - Method in class org.apache.druid.segment.nested.VariantColumn
- 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, 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(VectorColumnSelectorFactory, Expr) - Static method in class org.apache.druid.segment.virtual.ExpressionVectorSelectors
- 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
- makeYielder(Yielder<Sequence<T>>, OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.ConcatSequence
- makeZipf(String, ValueType, boolean, int, Double, int, int, Double) - Static method in class org.apache.druid.segment.generator.GeneratorColumnSchema
- manageLifecycle(Lifecycle, T) - Static method in class org.apache.druid.java.util.common.concurrent.ExecutorServices
- ManageLifecycle - Annotation Type in org.apache.druid.guice
-
Marks the object to be managed by
Lifecycle
and set to be onLifecycle.Stage.NORMAL
stage. - ManageLifecycleAnnouncements - Annotation Type in org.apache.druid.guice
-
Marks the object to be managed by
Lifecycle
and set to be onLifecycle.Stage.ANNOUNCEMENTS
stage. - ManageLifecycleInit - Annotation Type in org.apache.druid.guice
-
Marks the object to be managed by
Lifecycle
and set to be onLifecycle.Stage.INIT
stage. - ManageLifecycleServer - Annotation Type in org.apache.druid.guice
-
Marks the object to be managed by
Lifecycle
and set to be onLifecycle.Stage.SERVER
stage. - manipulate(AggregatorFactory, Object) - Method in interface org.apache.druid.query.aggregation.MetricManipulationFn
- MANY_TO_ONE - org.apache.druid.query.extraction.ExtractionFn.ExtractionType
- map(File) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Fully maps a file read-only in to memory as per
FileChannel.map(FileChannel.MapMode, long, long)
. - map(File) - Static method in class org.apache.druid.java.util.common.io.smoosh.Smoosh
- map(File, long, long) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Fully maps a file read-only in to memory as per
FileChannel.map(FileChannel.MapMode, long, long)
. - map(RandomAccessFile, long, long) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Fully maps a file read-only in to memory as per
FileChannel.map(FileChannel.MapMode, long, long)
. - map(Object, TypeRef<T>, Configuration) - Method in class org.apache.druid.java.util.common.parsers.NotImplementedMappingProvider
- map(Object, Class<T>, Configuration) - Method in class org.apache.druid.java.util.common.parsers.NotImplementedMappingProvider
- map(Function<? super T, ? extends U>) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- map(Function<? super T, ? extends U>) - Method in class org.apache.druid.query.Result
- map(Function<QueryRunner<T>, QueryRunner<T>>) - Method in class org.apache.druid.query.FluentQueryRunner
- map(Function<R, T>) - Method in class org.apache.druid.java.util.common.Either
-
Applies a function to this value, if present.
- map(Function<T, R>) - Method in interface org.apache.druid.java.util.common.parsers.CloseableIterator
- map(Sequence<From>, Function<? super From, ? extends To>) - Static method in class org.apache.druid.java.util.common.guava.Sequences
- MapBasedInputRow - Class in org.apache.druid.data.input
- MapBasedInputRow(long, List<String>, Map<String, Object>) - Constructor for class org.apache.druid.data.input.MapBasedInputRow
- MapBasedInputRow(DateTime, List<String>, Map<String, Object>) - Constructor for class org.apache.druid.data.input.MapBasedInputRow
- MapBasedRow - Class in org.apache.druid.data.input
- MapBasedRow(long, Map<String, Object>) - Constructor for class org.apache.druid.data.input.MapBasedRow
- MapBasedRow(DateTime, Map<String, Object>) - Constructor for class org.apache.druid.data.input.MapBasedRow
- mapDir(File) - Method in class org.apache.druid.segment.IndexIO.DefaultIndexIOHandler
- mapFile(String) - Method in class org.apache.druid.java.util.common.io.smoosh.SmooshedFileMapper
-
Returns a mapped buffer of the smooshed file with the given name.
- MapFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.MapFunction
- 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
- MapIndex - Class in org.apache.druid.segment.join.table
-
An
IndexedTable.Index
backed by a Map. - MapInputRowParser - Class in org.apache.druid.data.input.impl
- MapInputRowParser(ParseSpec) - Constructor for class org.apache.druid.data.input.impl.MapInputRowParser
- 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
- mapKeys(Map<K, V>, Function<K, K2>) - Static method in class org.apache.druid.utils.CollectionUtils
-
Returns a transformed map from the given input map where the key is modified based on the given keyMapper function.
- MapLookupExtractor - Class in org.apache.druid.query.extraction
-
Lookup extractor backed by any kind of map.
- MapLookupExtractor(Map<String, String>, boolean) - Constructor for class org.apache.druid.query.extraction.MapLookupExtractor
- MapOfColumnsRowsAndColumns - Class in org.apache.druid.query.rowsandcols
- MapOfColumnsRowsAndColumns(Map<String, Column>, int) - Constructor for class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- MapOfColumnsRowsAndColumns.Builder - Class in org.apache.druid.query.rowsandcols
- MappedByteBufferHandler - Class in org.apache.druid.java.util.common
-
Facilitates using try-with-resources with
MappedByteBuffer
. - MappedSequence<T,Out> - Class in org.apache.druid.java.util.common.guava
- MappedSequence(Sequence<T>, Function<? super T, ? extends Out>) - Constructor for class org.apache.druid.java.util.common.guava.MappedSequence
- MappingAccumulator<OutType,InType,MappedType> - Class in org.apache.druid.java.util.common.guava
- MappingYieldingAccumulator<OutType,InType,MappedType> - Class in org.apache.druid.java.util.common.guava
- MappingYieldingAccumulator(Function<? super InType, ? extends MappedType>, YieldingAccumulator<OutType, MappedType>) - Constructor for class org.apache.druid.java.util.common.guava.MappingYieldingAccumulator
- 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
- MapStringDynamicConfigProvider - Class in org.apache.druid.metadata
- MapStringDynamicConfigProvider(Map<String, String>) - Constructor for class org.apache.druid.metadata.MapStringDynamicConfigProvider
- MapUtils - Class in org.apache.druid.java.util.common
- MapUtils() - Constructor for class org.apache.druid.java.util.common.MapUtils
- mapValues(Map<K, V>, Function<V, V2>) - Static method in class org.apache.druid.utils.CollectionUtils
-
Returns a transformed map from the given input map where the value is modified based on the given valueMapper function.
- mapWritableChannel(Function<WritableFrameChannel, WritableFrameChannel>) - Method in class org.apache.druid.frame.processor.OutputChannel
- mapWritableChannel(Function<WritableFrameChannel, WritableFrameChannel>) - Method in class org.apache.druid.frame.processor.PartitionedOutputChannel
- MARIADB_PREFIX - Static variable in class org.apache.druid.utils.ConnectionUriUtils
- 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. - MARKER_FRAME - Static variable in class org.apache.druid.frame.file.FrameFileWriter
- MARKER_NO_MORE_FRAMES - Static variable in class org.apache.druid.frame.file.FrameFileWriter
- markTriviallyComplete() - Method in class org.apache.druid.frame.processor.SuperSorterProgressTracker
-
If the SuperSorter is trivially done without doing any work (for eg - empty input), the tracker can be marked as trivially complete.
- match(Object[], LambdaExpr, ApplyFunction.SettableLambdaBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.AllMatchFunction
- match(Object[], LambdaExpr, ApplyFunction.SettableLambdaBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.AnyMatchFunction
- match(Object[], LambdaExpr, ApplyFunction.SettableLambdaBinding) - Method in class org.apache.druid.math.expr.ApplyFunction.MatchFunction
- match(ReadableVectorMatch, boolean) - Method in class org.apache.druid.query.filter.vector.BooleanVectorValueMatcher
- match(ReadableVectorMatch, boolean) - Method in interface org.apache.druid.query.filter.vector.VectorValueMatcher
-
Examine the current vector and return a match indicating what is accepted.
- MATCH_ANY - org.apache.druid.query.filter.LikeDimFilter.LikeMatcher.SuffixMatch
- MATCH_EMPTY - org.apache.druid.query.filter.LikeDimFilter.LikeMatcher.SuffixMatch
- 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
- MATCH_PATTERN - org.apache.druid.query.filter.LikeDimFilter.LikeMatcher.SuffixMatch
- 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
- matchCondition(String, Predicate<String>) - Method in class org.apache.druid.guice.ConditionalMultibind
- matchCondition(String, String, Predicate<String>) - Method in class org.apache.druid.guice.ConditionalMultibind
- MatcherBundleInfo(Supplier<String>, FilterBundle.IndexBundleInfo, List<FilterBundle.MatcherBundleInfo>) - Constructor for class org.apache.druid.query.filter.FilterBundle.MatcherBundleInfo
- matches(boolean) - Method in enum org.apache.druid.query.filter.DruidPredicateMatch
-
Convenience method for
ValueMatcher
andVectorValueMatcher
implementations to pass through the 'includeUnknown' parameter to the predicate match result. - matches(boolean) - Method in interface org.apache.druid.query.filter.ValueMatcher
-
Returns true if the current row matches the condition.
- matches(String) - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
- matchesSuffixOnly(String) - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
-
Checks if the suffix of "value" matches the suffix of this matcher.
- MatchFunction() - Constructor for class org.apache.druid.math.expr.ApplyFunction.MatchFunction
- 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
- matchNulls(ReadableVectorMatch, VectorMatch, boolean[]) - Static method in interface org.apache.druid.query.filter.vector.VectorValueMatcher
- 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
- matchValue - Variable in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- max - Variable in class org.apache.druid.query.aggregation.Histogram
- max() - Method in annotation type org.apache.druid.java.util.common.HumanReadableBytesRange
-
upper bound of
HumanReadableBytes
. - max(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- max(DateTime, DateTime) - Static method in class org.apache.druid.java.util.common.DateTimes
- Max() - Constructor for class org.apache.druid.math.expr.Function.Max
- MAX - Static variable in class org.apache.druid.java.util.common.DateTimes
- MAX_ALLOWED_INTEGER - Static variable in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
The highest representable integer.
- MAX_DEFAULT_PROCESSING_BUFFER_SIZE_BYTES - Static variable in class org.apache.druid.query.DruidProcessingBufferConfig
- MAX_ERROR_MSG_LENGTH - Static variable in class org.apache.druid.indexer.TaskStatus
- MAX_INSTANT - Static variable in class org.apache.druid.java.util.common.JodaUtils
- 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_LITERAL_LENGTH - Static variable in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Maximum number of representable bits within a literal
- MAX_NUMERIC_IN_FILTERS - Static variable in class org.apache.druid.query.QueryContexts
- MAX_OVERFLOW_REGISTER_BYTE - Static variable in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- MAX_OVERFLOW_VALUE_BYTE - Static variable in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- MAX_PARTITION_SIZE - Static variable in interface org.apache.druid.indexer.partitions.DimensionBasedPartitionsSpec
- MAX_QUEUED_BYTES_KEY - Static variable in class org.apache.druid.query.QueryContexts
- MAX_ROWS_PER_SEGMENT - Static variable in interface org.apache.druid.indexer.partitions.PartitionsSpec
- MAX_SCATTER_GATHER_BYTES_KEY - Static variable in class org.apache.druid.query.QueryContexts
- MAX_SLEEP_MILLIS - Static variable in class org.apache.druid.java.util.common.RetryUtils
- MAX_SUBQUERY_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
- MAX_TIME_ARRAY_OUTPUT_NAME - 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.AppendableIndexBuilder
- maxBytesInMemory - Variable in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
- maxDateTime(DateTime...) - Static method in class org.apache.druid.java.util.common.JodaUtils
- maxIntsInBufferForBytes(int) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
- maxIntsInBufferForValue(int) - Static method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
- maxLiteralLengthDivision(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Calculates the division by 31
- maxLiteralLengthModulus(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Calculates the modulus division by 31 in a faster way than using
n % 31
- maxLiteralLengthMultiplication(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Calculates the multiplication by 31 in a faster way than using
n * 31
- maxLoadFactor - Variable in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
- maxLoadFactor - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- maxRetry(int) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- maxRowCount - Variable in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- maxRowCount - Variable in class org.apache.druid.segment.incremental.OnheapIncrementalIndex
- maxSize() - Method in interface org.apache.druid.collections.BlockingPool
- maxSize() - Method in class org.apache.druid.collections.DefaultBlockingPool
- maxSize() - Method in class org.apache.druid.collections.DummyBlockingPool
- 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
- MaxSizeSplitHintSpec - Class in org.apache.druid.data.input
-
A SplitHintSpec that can create splits of multiple files.
- MaxSizeSplitHintSpec(long, Integer) - Constructor for class org.apache.druid.data.input.MaxSizeSplitHintSpec
- MaxSizeSplitHintSpec(HumanReadableBytes, Integer) - Constructor for class org.apache.druid.data.input.MaxSizeSplitHintSpec
- maxStringBytes - Variable in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- maxStringBytes - Variable in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- maybeAnd(List<Filter>) - Static method in class org.apache.druid.segment.filter.Filters
-
Like
Filters.and(java.util.List<org.apache.druid.query.filter.Filter>)
, but returns an empty Optional instead of throwing an exception if "filters" is empty or only contains nulls. - maybeAppendTrailingSlash(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- maybeOr(List<Filter>) - Static method in class org.apache.druid.segment.filter.Filters
-
Like
Filters.or(java.util.List<org.apache.druid.query.filter.Filter>)
, but returns an empty Optional instead of throwing an exception if "filters" is empty or only contains nulls. - maybeRemoveLeadingSlash(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- maybeRemoveTrailingSlash(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- maybeWithBaseQuery(Query<?>) - Method in class org.apache.druid.query.planning.DataSourceAnalysis
-
Returns the data source analysis with or without the updated query.
- 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 - Variable in class org.apache.druid.frame.field.NumericArrayFieldSelector
-
Memory containing the serialized values of the array
- memory() - Method in class org.apache.druid.frame.allocation.MemoryRange
-
Returns the underlying memory *without* clipping it to this particular range.
- memory() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
-
Returns the memory backing this table.
- memory() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryPointer
- Memory - Class in org.apache.druid.java.util.metrics.cgroups
- Memory(CgroupDiscoverer) - Constructor for class org.apache.druid.java.util.metrics.cgroups.Memory
- Memory.MemoryStat - Class in org.apache.druid.java.util.metrics.cgroups
- MemoryAllocator - Interface in org.apache.druid.frame.allocation
-
Allocator of WritableMemory.
- MemoryAllocatorFactory - Interface in org.apache.druid.frame.allocation
-
Factory for
MemoryAllocator
. - MemoryBoundLinkedBlockingQueue<T> - Class in org.apache.druid.java.util.common
-
Similar to LinkedBlockingQueue but can be bounded by the total byte size of the items present in the queue rather than number of items.
- MemoryBoundLinkedBlockingQueue(long) - Constructor for class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
- MemoryBoundLinkedBlockingQueue.ObjectContainer<T> - Class in org.apache.druid.java.util.common
- memoryEquals(Memory, long, Memory, long, int) - Static method in class org.apache.druid.query.groupby.epinephelinae.collection.HashTableUtils
-
Compare two memory ranges for equality.
- MemoryFootprint<T> - Class in org.apache.druid.query.groupby.epinephelinae.column
-
Holder for a value and the memory increase in the internal dictionary associated with the increase
- memoryIncrease() - Method in class org.apache.druid.query.groupby.epinephelinae.column.MemoryFootprint
- 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
- MemoryPointer - Class in org.apache.druid.query.groupby.epinephelinae.collection
-
Reusable pointer to a location in
Memory
. - MemoryPointer() - Constructor for class org.apache.druid.query.groupby.epinephelinae.collection.MemoryPointer
- MemoryPointer(Memory, long) - Constructor for class org.apache.druid.query.groupby.epinephelinae.collection.MemoryPointer
- MemoryRange<T extends org.apache.datasketches.memory.Memory> - Class in org.apache.druid.frame.allocation
-
Reference to a particular region of some
Memory
. - MemoryRange(T, long, long) - Constructor for class org.apache.druid.frame.allocation.MemoryRange
- MemoryStat() - Constructor for class org.apache.druid.java.util.metrics.cgroups.Memory.MemoryStat
- merge(boolean) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- merge(byte, boolean) - Method in class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- merge(List<IndexableAdapter>, boolean, AggregatorFactory[], File, DimensionsSpec, IndexSpec, int) - Method in interface org.apache.druid.segment.IndexMerger
-
Only used as a convenience method in tests.
- merge(List<IndexableAdapter>, boolean, AggregatorFactory[], File, DimensionsSpec, IndexSpec, int) - Method in class org.apache.druid.segment.IndexMergerV9
- merge(List<Metadata>, AggregatorFactory[]) - Static method in class org.apache.druid.segment.Metadata
- merge(ResponseContext) - Method in class org.apache.druid.query.context.ResponseContext
-
Merges a response context into the current.
- merge(ColumnFormat) - Method in class org.apache.druid.segment.column.CapabilitiesBasedFormat
- merge(ColumnFormat) - Method in interface org.apache.druid.segment.column.ColumnFormat
- merge(ColumnFormat) - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumn.Format
- merge(ColumnFormat) - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde.NestedColumnFormatV4
- merge(ColumnIndexCapabilities) - Method in interface org.apache.druid.segment.column.ColumnIndexCapabilities
- merge(ColumnIndexCapabilities) - Method in class org.apache.druid.segment.column.SimpleColumnIndexCapabilities
- merge(StructuredDataProcessor.ProcessResults) - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
- merge(SegmentSchemaMapping) - Method in class org.apache.druid.segment.SegmentSchemaMapping
-
Merge with another instance.
- 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(Set<String>, SegmentAnalysis, SegmentAnalysis, AggregatorMergeStrategy) - 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 ascendingint
values. - mergeBitmaps(List<IntBuffer>, BitmapFactory, DictionaryEncodedColumnMerger.IndexSeeker[], int) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- merged(String, Interval, int) - Static method in class org.apache.druid.timeline.SegmentId
-
Creates a merged SegmentId for the given data source, interval and partition number.
- mergeFieldsInto(SortedMap<String, FieldTypeInfo.MutableTypeSet>) - Method in class org.apache.druid.segment.IndexableAdapter.NestedColumnMergable
- mergeGranularities(List<Granularity>) - Static method in class org.apache.druid.java.util.common.granularity.Granularity
-
simple merge strategy on query granularity that checks if all are equal or else returns null.
- mergeIndexed(List<Iterable<T>>) - Static method in interface org.apache.druid.segment.IndexMerger
- mergeIndexes(int, MutableBitmap) - Method in interface org.apache.druid.segment.DictionaryEncodedColumnMerger.ExtendedIndexesMerger
-
Merge extended indexes for the given dictionaryId value.
- mergeIndexes(int, MutableBitmap) - Method in class org.apache.druid.segment.StringDimensionMergerV9.SpatialIndexesMerger
- MergeIterable<T> - Class in org.apache.druid.java.util.common.guava
- MergeIterable(Iterable<? extends Iterable<? extends T>>, Comparator<? super T>) - Constructor for class org.apache.druid.java.util.common.guava.MergeIterable
- MergeIterator<T> - Class in org.apache.druid.java.util.common.guava
-
Iterator that merges a collection of sorted iterators using a comparator.
- MergeIterator(Iterable<? extends Iterator<? extends T>>, Comparator<? super T>) - Constructor for class org.apache.druid.java.util.common.guava.MergeIterator
- mergeQueryableIndex(List<QueryableIndex>, boolean, AggregatorFactory[], File, IndexSpec, SegmentWriteOutMediumFactory, int) - Method in interface org.apache.druid.segment.IndexMerger
-
Merge a collection of
QueryableIndex
. - mergeQueryableIndex(List<QueryableIndex>, boolean, AggregatorFactory[], DimensionsSpec, File, IndexSpec, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory, int) - Method in interface org.apache.druid.segment.IndexMerger
-
Merge a collection of
QueryableIndex
. - mergeQueryableIndex(List<QueryableIndex>, boolean, AggregatorFactory[], DimensionsSpec, File, IndexSpec, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory, int) - Method in class org.apache.druid.segment.IndexMergerV9
- mergeResults(boolean) - Method in class org.apache.druid.query.FluentQueryRunner
-
Delegates to
QueryToolChest.mergeResults(QueryRunner, boolean)
. - mergeResults(List<Result<DataSourceMetadataResultValue>>) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQuery
- mergeResults(List<Result<TimeBoundaryResultValue>>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
- mergeResults(QueryRunner<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- mergeResults(QueryRunner<ResultRow>, boolean) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- mergeResults(QueryRunner<ResultRow>, GroupByQuery, ResponseContext) - Method in class org.apache.druid.query.groupby.GroupingEngine
-
Runs a provided
QueryRunner
on a providedGroupByQuery
, 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<SegmentAnalysis>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryQueryToolChest
- mergeResults(QueryRunner<Result<DataSourceMetadataResultValue>>) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceQueryQueryToolChest
- 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
- mergeResults(QueryRunner<Result<TopNResultValue>>) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
- mergeResults(QueryRunner<RowsAndColumns>) - Method in class org.apache.druid.query.operator.WindowOperatorQueryQueryToolChest
- mergeResults(QueryRunner<ScanResultValue>) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
- mergeResults(QueryRunner<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
-
This method wraps a QueryRunner.
- mergeResults(QueryRunner<ResultType>, boolean) - Method in class org.apache.druid.query.QueryToolChest
-
Like
QueryToolChest.mergeResults(QueryRunner)
, but with an additional flag that indicates the type of runner that is passeed to the call. - mergeRunners(ExecutorService, Iterable<QueryRunner<T>>) - Method in interface org.apache.druid.query.QueryRunnerFactory
-
Deprecated.Use
QueryRunnerFactory.mergeRunners(QueryProcessingPool, Iterable)
instead. Runners generated with createRunner() and combined into an Iterable in (time,shardId) order are passed along to this method with anExecutorService
. The method should then return aQueryRunner
that, when asked, will use theExecutorService
to run the base QueryRunners in some fashion. The vast majority of the time, this should be implemented withChainedExecutionQueryRunner
: return new ChainedExecutionQueryRunner<>(queryExecutor, toolChest.getOrdering(), queryWatcher, queryRunners); Which will allow for parallel execution up to the maximum number of processing threads allowed. - mergeRunners(QueryProcessingPool, Iterable<QueryRunner<ResultRow>>) - Method in class org.apache.druid.query.groupby.GroupByQueryRunnerFactory
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<ResultRow>>) - Method in class org.apache.druid.query.groupby.GroupingEngine
-
Merges a variety of single-segment query runners into a combined runner.
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<SegmentAnalysis>>) - Method in class org.apache.druid.query.metadata.SegmentMetadataQueryRunnerFactory
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<Result<DataSourceMetadataResultValue>>>) - Method in class org.apache.druid.query.datasourcemetadata.DataSourceMetadataQueryRunnerFactory
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<Result<SearchResultValue>>>) - Method in class org.apache.druid.query.search.SearchQueryRunnerFactory
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<Result<TimeBoundaryResultValue>>>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryRunnerFactory
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<Result<TimeseriesResultValue>>>) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryRunnerFactory
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<Result<TopNResultValue>>>) - Method in class org.apache.druid.query.topn.TopNQueryRunnerFactory
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<RowsAndColumns>>) - Method in class org.apache.druid.query.operator.WindowOperatorQueryQueryRunnerFactory
- mergeRunners(QueryProcessingPool, Iterable<QueryRunner<ScanResultValue>>) - Method in class org.apache.druid.query.scan.ScanQueryRunnerFactory
- mergeRunners(QueryProcessingPool, 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
QueryProcessingPool
. - MergeSequence<T> - Class in org.apache.druid.java.util.common.guava
-
Used to perform an n-way merge on n ordered sequences
- MergeSequence(Ordering<? super T>, Sequence<? extends Sequence<? extends T>>) - Constructor for class org.apache.druid.java.util.common.guava.MergeSequence
- mergeSorted(Iterable<? extends Iterator<? extends T>>, Comparator<? super T>) - Static method in class org.apache.druid.java.util.common.collect.Utils
-
Like Guava's
Iterators.mergeSorted(Iterable, Comparator)
, but avoids calling next() on any iterator prior to returning the value returned by the previous call to next(). - mergeSorted(List<? extends CloseableIterator<? extends T>>, Comparator<T>) - Static method in class org.apache.druid.java.util.common.CloseableIterators
- mergeTimestampSpec(List<TimestampSpec>) - Static method in class org.apache.druid.data.input.impl.TimestampSpec
- mergeValues(Object, Object) - Method in class org.apache.druid.query.context.ResponseContext.BooleanKey
- mergeValues(Object, Object) - Method in class org.apache.druid.query.context.ResponseContext.CounterKey
- mergeValues(Object, Object) - Method in interface org.apache.druid.query.context.ResponseContext.Key
-
Merges two values of type T.
- mergeValues(Object, Object) - Method in class org.apache.druid.query.context.ResponseContext.LongKey
- mergeValues(Object, Object) - Method in class org.apache.druid.query.context.ResponseContext.StringKey
- Merging - Annotation Type in org.apache.druid.guice.annotations
- message() - Method in annotation type org.apache.druid.java.util.common.HumanReadableBytesRange
- message(String, ColumnType) - Static method in exception org.apache.druid.frame.write.UnsupportedColumnTypeException
- Metadata - Class in org.apache.druid.segment
- Metadata(Map<String, Object>, AggregatorFactory[], TimestampSpec, Granularity, Boolean) - Constructor for class org.apache.druid.segment.Metadata
- MetadataCASUpdate - Class in org.apache.druid.metadata
-
Expresses a single compare-and-swap update for MetadataStorageConnector's compareAndSwap method
- MetadataCASUpdate(String, String, String, String, byte[], byte[]) - Constructor for class org.apache.druid.metadata.MetadataCASUpdate
- MetadataStorageActionHandler<EntryType,StatusType,LogType,LockType> - Interface in org.apache.druid.metadata
- MetadataStorageActionHandlerFactory - Interface in org.apache.druid.metadata
- MetadataStorageActionHandlerTypes<EntryType,StatusType,LogType,LockType> - Interface in org.apache.druid.metadata
- MetadataStorageConnector - Interface in org.apache.druid.metadata
- MetadataStorageConnectorConfig - Class in org.apache.druid.metadata
- MetadataStorageConnectorConfig() - Constructor for class org.apache.druid.metadata.MetadataStorageConnectorConfig
- MetadataStorageTablesConfig - Class in org.apache.druid.metadata
- MetadataStorageTablesConfig(String, String, String, String, String, String, String, String, String, String, String, String, String) - Constructor for class org.apache.druid.metadata.MetadataStorageTablesConfig
- MetadataStorageUpdaterJobHandler - Interface in org.apache.druid.indexer
- 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
- meters - org.apache.druid.collections.spatial.search.RadiusBound.RadiusUnit
- metric(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- metric(TopNMetricSpec) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- 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
- metrics(List<String>) - Method in class org.apache.druid.timeline.DataSegment.Builder
- MetricsEmittingQueryProcessingPool - Class in org.apache.druid.query
- MetricsEmittingQueryProcessingPool(ListeningExecutorService, ExecutorServiceMonitor) - Constructor for class org.apache.druid.query.MetricsEmittingQueryProcessingPool
- 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
- MICROSECOND - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- miles - org.apache.druid.collections.spatial.search.RadiusBound.RadiusUnit
- MILLENNIUM - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- MILLISECOND - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- millisElapsed() - Method in class org.apache.druid.java.util.common.Stopwatch
-
Returns the milliseconds elapsed on the stopwatch.
- min - Variable in class org.apache.druid.query.aggregation.Histogram
- min() - Method in annotation type org.apache.druid.java.util.common.HumanReadableBytesRange
-
lower bound of
HumanReadableBytes
. - min(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- min(DateTime, DateTime) - Static method in class org.apache.druid.java.util.common.DateTimes
- Min() - Constructor for class org.apache.druid.math.expr.Function.Min
- MIN - Static variable in class org.apache.druid.java.util.common.DateTimes
- MIN_ALLOWED_SET_BIT - Static variable in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
The lowest representable integer.
- MIN_INSTANT - Static variable in class org.apache.druid.java.util.common.JodaUtils
- MIN_TIME - Static variable in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
- MIN_TIME_ARRAY_OUTPUT_NAME - Static variable in class org.apache.druid.query.timeboundary.TimeBoundaryQuery
- MIN_TOP_N_THRESHOLD - Static variable in class org.apache.druid.query.QueryContexts
- minDateTime(DateTime...) - Static method in class org.apache.druid.java.util.common.JodaUtils
- minimal() - Static method in class org.apache.druid.frame.channel.BlockingQueueFrameChannel
-
Create a channel that buffers one frame.
- MINMAX - org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
- minus(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- MINUS - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- MINUS - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- MINUTE - org.apache.druid.java.util.common.granularity.GranularityType
- MINUTE - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- MINUTE - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- MISSING_SEGMENTS - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
Lists missing segments.
- mkdirp(File) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Create "directory" and all intermediate directories as needed.
- MMappedIndex - Class in org.apache.druid.segment
- MMappedIndex(GenericIndexed<String>, GenericIndexed<String>, Interval, CompressedColumnarLongsSupplier, Map<String, MetricHolder>, Map<String, GenericIndexed<ByteBuffer>>, 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
- modeNames - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- ModulesConfig - Class in org.apache.druid.guice
- ModulesConfig() - Constructor for class org.apache.druid.guice.ModulesConfig
- modulo(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- MODULO - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- MODULO - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- 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
- monitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.AbstractMonitor
- monitor(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.CompoundMonitor
- monitor(ServiceEmitter) - Method in interface org.apache.druid.java.util.metrics.Monitor
-
Emit metrics using the given emitter.
- Monitor - Interface in org.apache.druid.java.util.metrics
- monitorCpuStats(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- monitorDiskStats(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- monitorFsStats(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- monitorMemStats(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- monitorNetStats(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- Monitors - Class in org.apache.druid.java.util.metrics
- Monitors() - Constructor for class org.apache.druid.java.util.metrics.Monitors
- MonitorScheduler - Class in org.apache.druid.java.util.metrics
- monitorSwapStats(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- monitorSysStats(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- monitorTcpStats(ServiceEmitter) - Method in class org.apache.druid.java.util.metrics.OshiSysMonitor
- MonitorUtils - Class in org.apache.druid.java.util.metrics
- MonitorUtils() - Constructor for class org.apache.druid.java.util.metrics.MonitorUtils
- MONTH - org.apache.druid.java.util.common.granularity.GranularityType
- MONTH - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- MONTH - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- moreData(RowsAndColumns) - Method in interface org.apache.druid.query.rowsandcols.semantic.NaiveSortMaker.NaiveSorter
-
Adds more data to the sort.
- move(DataSegment, Map<String, Object>) - Method in interface org.apache.druid.segment.loading.DataSegmentMover
- 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.
- MUL - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- MUL - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- MulDivModuloExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.MulDivModuloExprContext
- MULTI_VALUE - org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.Feature
- MULTI_VALUE_V3 - org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.Feature
- MultiColumnSelectorFactory - Class in org.apache.druid.frame.processor
-
A
ColumnSelectorFactory
that wraps multipleColumnSelectorFactory
and delegates to one of them at any given time. - MultiColumnSelectorFactory(List<Supplier<ColumnSelectorFactory>>, RowSignature) - Constructor for class org.apache.druid.frame.processor.MultiColumnSelectorFactory
- multiConstant(List<String>) - Static method in interface org.apache.druid.segment.DimensionSelector
- multiConstant(List<String>, ExtractionFn) - Static method in interface org.apache.druid.segment.DimensionSelector
- 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()
isColumnCapabilities.Capable.UNKNOWN
, define if it should be treated as true or false. - multiply(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- multiThreaded(int, String) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- multiThreaded(int, String, Integer) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- multiValue - Variable in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
- MultiValueDimensionVectorSelector - Interface in org.apache.druid.segment.vector
-
Vectorized selector for a multi-valued string-typed column.
- MultiValueStringCardinalityVectorProcessor - Class in org.apache.druid.query.aggregation.cardinality.vector
- MultiValueStringCardinalityVectorProcessor(MultiValueDimensionVectorSelector) - Constructor for class org.apache.druid.query.aggregation.cardinality.vector.MultiValueStringCardinalityVectorProcessor
- MultiValueStringHarmonizeNullsFunction() - Constructor for class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- MultiValueStringToArrayFunction() - Constructor for class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- MultiValueStringVectorObjectSelector(ColumnarMultiInts, ReadableVectorOffset) - Constructor for class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.MultiValueStringVectorObjectSelector
- MultiValueStringVectorValueMatcher - Class in org.apache.druid.query.filter.vector
- MultiValueStringVectorValueMatcher(MultiValueDimensionVectorSelector) - Constructor for class org.apache.druid.query.filter.vector.MultiValueStringVectorValueMatcher
- MURMUR3_32_ABS - org.apache.druid.timeline.partition.HashPartitionFunction
- mustCombineNullAndEmptyInDictionary(Indexed<ByteBuffer>) - Static method in class org.apache.druid.common.config.NullHandling
-
Given a UTF-8 dictionary, returns whether the first two entries must be coalesced into a single null entry.
- 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
- mustReplaceFirstValueWithNullInDictionary(Indexed<ByteBuffer>) - Static method in class org.apache.druid.common.config.NullHandling
-
Given a UTF-8 dictionary, returns whether the first entry must be replaced with null.
- MutableBitmap - Interface in org.apache.druid.collections.bitmap
-
This class is meant to represent a simple wrapper around a bitmap class.
- MutableTypeSet() - Constructor for class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- MutableTypeSet(byte) - Constructor for class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- MutableTypeSet(byte, boolean) - Constructor for class org.apache.druid.segment.nested.FieldTypeInfo.MutableTypeSet
- MYSQL_CONNECTION_URL - Static variable in class org.apache.druid.utils.ConnectionUriUtils
- MYSQL_HOST_INFO - Static variable in class org.apache.druid.utils.ConnectionUriUtils
- MYSQL_PREFIX - Static variable in class org.apache.druid.utils.ConnectionUriUtils
N
- NaivePartitioningOperator - Class in org.apache.druid.query.operator
-
This naive partitioning operator assumes that it's child operator always gives it RowsAndColumns objects that are a superset of the partitions that it needs to provide.
- NaivePartitioningOperator(List<String>, Operator) - Constructor for class org.apache.druid.query.operator.NaivePartitioningOperator
- NaivePartitioningOperatorFactory - Class in org.apache.druid.query.operator
- NaivePartitioningOperatorFactory(List<String>) - Constructor for class org.apache.druid.query.operator.NaivePartitioningOperatorFactory
- NaiveSortMaker - Interface in org.apache.druid.query.rowsandcols.semantic
-
A NaiveSorter sorts a stream of data in-place.
- NaiveSortMaker.NaiveSorter - Interface in org.apache.druid.query.rowsandcols.semantic
- NaiveSortOperator - Class in org.apache.druid.query.operator
-
A naive sort operator is an operation that sorts a stream of data in-place.
- NaiveSortOperator(Operator, List<ColumnWithDirection>) - Constructor for class org.apache.druid.query.operator.NaiveSortOperator
- NaiveSortOperatorFactory - Class in org.apache.druid.query.operator
- NaiveSortOperatorFactory(List<ColumnWithDirection>) - Constructor for class org.apache.druid.query.operator.NaiveSortOperatorFactory
- 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 - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- name() - Method in class org.apache.druid.math.expr.ApplyFunction.AllMatchFunction
- name() - Method in class org.apache.druid.math.expr.ApplyFunction.AnyMatchFunction
- name() - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldFunction
- name() - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianMapFunction
- name() - Method in class org.apache.druid.math.expr.ApplyFunction.FilterFunction
- name() - Method in class org.apache.druid.math.expr.ApplyFunction.FoldFunction
- name() - Method in class org.apache.druid.math.expr.ApplyFunction.MapFunction
- name() - Method in class org.apache.druid.math.expr.BuiltInExprMacros.ComplexDecodeBase64ExprMacro
-
use name() in closure scope to allow Alias macro to override it with alias.
- name() - Method in class org.apache.druid.math.expr.BuiltInExprMacros.StringDecodeBase64UTFExprMacro
-
use name() in closure scope to allow Alias macro to override it with alias.
- name() - Method in class org.apache.druid.math.expr.Function.Abs
- name() - Method in class org.apache.druid.math.expr.Function.Acos
- name() - Method in class org.apache.druid.math.expr.Function.ArrayAppendFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayConcatFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayConstructorFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayLengthFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayOffsetFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayOffsetOfFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayOrdinalFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayOrdinalOfFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayPrependFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArraySetAddAllFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArraySetAddFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArraySliceFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- name() - Method in class org.apache.druid.math.expr.Function.ArrayToStringFunction
- name() - Method in class org.apache.druid.math.expr.Function.Asin
- name() - Method in class org.apache.druid.math.expr.Function.Atan
- name() - Method in class org.apache.druid.math.expr.Function.Atan2
- name() - Method in class org.apache.druid.math.expr.Function.BitwiseAnd
- name() - Method in class org.apache.druid.math.expr.Function.BitwiseComplement
- name() - Method in class org.apache.druid.math.expr.Function.BitwiseConvertDoubleToLongBits
- name() - Method in class org.apache.druid.math.expr.Function.BitwiseConvertLongBitsToDouble
- name() - Method in class org.apache.druid.math.expr.Function.BitwiseOr
- name() - Method in class org.apache.druid.math.expr.Function.BitwiseShiftLeft
- name() - Method in class org.apache.druid.math.expr.Function.BitwiseShiftRight
- name() - Method in class org.apache.druid.math.expr.Function.BitwiseXor
- name() - Method in class org.apache.druid.math.expr.Function.CaseSearchedFunc
- name() - Method in class org.apache.druid.math.expr.Function.CaseSimpleFunc
- name() - Method in class org.apache.druid.math.expr.Function.CastFunc
- name() - Method in class org.apache.druid.math.expr.Function.Cbrt
- name() - Method in class org.apache.druid.math.expr.Function.Ceil
- name() - Method in class org.apache.druid.math.expr.Function.CoalesceFunc
- name() - Method in class org.apache.druid.math.expr.Function.ConcatFunc
- name() - Method in class org.apache.druid.math.expr.Function.ConditionFunc
- name() - Method in class org.apache.druid.math.expr.Function.CopySign
- name() - Method in class org.apache.druid.math.expr.Function.Cos
- name() - Method in class org.apache.druid.math.expr.Function.Cosh
- name() - Method in class org.apache.druid.math.expr.Function.Cot
- name() - Method in class org.apache.druid.math.expr.Function.Div
- name() - Method in class org.apache.druid.math.expr.Function.Exp
- name() - Method in class org.apache.druid.math.expr.Function.Expm1
- name() - Method in class org.apache.druid.math.expr.Function.Floor
- name() - Method in class org.apache.druid.math.expr.Function.GetExponent
- name() - Method in class org.apache.druid.math.expr.Function.GreatestFunc
- name() - Method in class org.apache.druid.math.expr.Function.HumanReadableBinaryByteFormatFunc
- name() - Method in class org.apache.druid.math.expr.Function.HumanReadableDecimalByteFormatFunc
- name() - Method in class org.apache.druid.math.expr.Function.HumanReadableDecimalFormatFunc
- name() - Method in class org.apache.druid.math.expr.Function.Hypot
- name() - Method in class org.apache.druid.math.expr.Function.IsDistinctFromFunc
- name() - Method in class org.apache.druid.math.expr.Function.IsFalseFunc
- name() - Method in class org.apache.druid.math.expr.Function.IsNotDistinctFromFunc
- name() - Method in class org.apache.druid.math.expr.Function.IsNotFalseFunc
- name() - Method in class org.apache.druid.math.expr.Function.IsNotNullFunc
- name() - Method in class org.apache.druid.math.expr.Function.IsNotTrueFunc
- name() - Method in class org.apache.druid.math.expr.Function.IsNullFunc
- name() - Method in class org.apache.druid.math.expr.Function.IsTrueFunc
- name() - Method in class org.apache.druid.math.expr.Function.LeastFunc
- name() - Method in class org.apache.druid.math.expr.Function.LeftFunc
- name() - Method in class org.apache.druid.math.expr.Function.Log
- name() - Method in class org.apache.druid.math.expr.Function.Log10
- name() - Method in class org.apache.druid.math.expr.Function.Log1p
- name() - Method in class org.apache.druid.math.expr.Function.LowerFunc
- name() - Method in class org.apache.druid.math.expr.Function.LpadFunc
- name() - Method in class org.apache.druid.math.expr.Function.Max
- name() - Method in class org.apache.druid.math.expr.Function.Min
- name() - Method in class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- name() - Method in class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- name() - Method in class org.apache.druid.math.expr.Function.NextAfter
- name() - Method in class org.apache.druid.math.expr.Function.NextUp
- name() - Method in class org.apache.druid.math.expr.Function.NvlFunc
- name() - Method in class org.apache.druid.math.expr.Function.ParseLong
- name() - Method in class org.apache.druid.math.expr.Function.Pi
- name() - Method in class org.apache.druid.math.expr.Function.Pow
- name() - Method in class org.apache.druid.math.expr.Function.Remainder
- name() - Method in class org.apache.druid.math.expr.Function.RepeatFunc
- name() - Method in class org.apache.druid.math.expr.Function.ReplaceFunc
- name() - Method in class org.apache.druid.math.expr.Function.ReverseFunc
- name() - Method in class org.apache.druid.math.expr.Function.RightFunc
- name() - Method in class org.apache.druid.math.expr.Function.Rint
- name() - Method in class org.apache.druid.math.expr.Function.Round
- name() - Method in class org.apache.druid.math.expr.Function.RpadFunc
- name() - Method in class org.apache.druid.math.expr.Function.SafeDivide
- name() - Method in class org.apache.druid.math.expr.Function.ScalarInArrayFunction
- name() - Method in class org.apache.druid.math.expr.Function.Scalb
- name() - Method in class org.apache.druid.math.expr.Function.Signum
- name() - Method in class org.apache.druid.math.expr.Function.Sin
- name() - Method in class org.apache.druid.math.expr.Function.Sinh
- name() - Method in class org.apache.druid.math.expr.Function.Sqrt
- name() - Method in class org.apache.druid.math.expr.Function.StringFormatFunc
- name() - Method in class org.apache.druid.math.expr.Function.StringToArrayFunction
- name() - Method in class org.apache.druid.math.expr.Function.StrlenFunc
- name() - Method in class org.apache.druid.math.expr.Function.StrposFunc
- name() - Method in class org.apache.druid.math.expr.Function.SubMonthFunc
- name() - Method in class org.apache.druid.math.expr.Function.SubstringFunc
- name() - Method in class org.apache.druid.math.expr.Function.Tan
- name() - Method in class org.apache.druid.math.expr.Function.Tanh
- name() - Method in class org.apache.druid.math.expr.Function.TimestampFromEpochFunc
- name() - Method in class org.apache.druid.math.expr.Function.ToDegrees
- name() - Method in class org.apache.druid.math.expr.Function.ToRadians
- name() - Method in class org.apache.druid.math.expr.Function.Ulp
- name() - Method in class org.apache.druid.math.expr.Function.UnixTimestampFunc
- name() - Method in class org.apache.druid.math.expr.Function.UpperFunc
- name() - Method in interface org.apache.druid.math.expr.NamedFunction
-
Name of the function
- name() - Method in class org.apache.druid.query.expression.ArrayQuantileExprMacro
- 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.HyperUniqueExpressions.HllAddExprMacro
- name() - Method in class org.apache.druid.query.expression.HyperUniqueExpressions.HllCreateExprMacro
- name() - Method in class org.apache.druid.query.expression.HyperUniqueExpressions.HllEstimateExprMacro
- name() - Method in class org.apache.druid.query.expression.HyperUniqueExpressions.HllRoundEstimateExprMacro
- 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.IPv6AddressMatchExprMacro
- 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.NestedDataExpressions.JsonKeysExprMacro
- name() - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonObjectExprMacro
- name() - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonPathsExprMacro
- name() - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonQueryArrayExprMacro
- name() - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonQueryExprMacro
- name() - Method in class org.apache.druid.query.expression.NestedDataExpressions.JsonValueExprMacro
- name() - Method in class org.apache.druid.query.expression.NestedDataExpressions.ParseJsonExprMacro
- name() - Method in class org.apache.druid.query.expression.NestedDataExpressions.ToJsonStringExprMacro
- name() - Method in class org.apache.druid.query.expression.NestedDataExpressions.TryParseJsonExprMacro
- 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.RegexpReplaceExprMacro
- 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.indexer.partitions.DimensionRangePartitionsSpec
- NAME - Static variable in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- NAME - Static variable in class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
- NAME - Static variable in class org.apache.druid.math.expr.BuiltInExprMacros.ComplexDecodeBase64ExprMacro
- NAME - Static variable in class org.apache.druid.math.expr.BuiltInExprMacros.StringDecodeBase64UTFExprMacro
- NAME - Static variable in class org.apache.druid.math.expr.Function.GreatestFunc
- NAME - Static variable in class org.apache.druid.math.expr.Function.LeastFunc
- NAME - Static variable in class org.apache.druid.math.expr.Function.Round
- NAME - Static variable in class org.apache.druid.math.expr.Function.SafeDivide
- NAME - Static variable in class org.apache.druid.query.expression.HyperUniqueExpressions.HllEstimateExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.HyperUniqueExpressions.HllRoundEstimateExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.JsonKeysExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.JsonObjectExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.JsonPathsExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.JsonQueryArrayExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.JsonQueryExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.JsonValueExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.ParseJsonExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.ToJsonStringExprMacro
- NAME - Static variable in class org.apache.druid.query.expression.NestedDataExpressions.TryParseJsonExprMacro
- NAME - Static variable in class org.apache.druid.query.search.CursorOnlyStrategy
- NAME - Static variable in class org.apache.druid.query.search.UseIndexesStrategy
- NamedFunction - Interface in org.apache.druid.math.expr
-
Common stuff for "named" functions of "functional" expressions, such as
FunctionExpr
,ApplyFunctionExpr
, andExprMacroTable.ExprMacroFunctionExpr
. - nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.BaseSingleValueDimensionSelector
- nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringMultiValueDimensionVectorSelector
- nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringSingleValueDimensionVectorSelector
- nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.ConstantDimensionSelector
- nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.ConstantMultiValueDimensionSelector
- nameLookupPossibleInAdvance() - Method in interface org.apache.druid.segment.DimensionDictionarySelector
-
Returns true if it is possible to
DimensionDictionarySelector.lookupName(int)
by ids from 0 toDimensionDictionarySelector.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.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- nameLookupPossibleInAdvance() - Method in class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector
- NativeClearedByteBufferProvider - Class in org.apache.druid.segment.serde.cell
-
supplies direct, 64k, clear()'d ByteBuffers wrapped in a ResourceHolder.
- NativeClearedByteBufferProvider() - Constructor for class org.apache.druid.segment.serde.cell.NativeClearedByteBufferProvider
- NativeIO - Class in org.apache.druid.java.util.common.io
-
Native I/O operations in order to minimize cache impact.
- NativeQuery - Annotation Type in org.apache.druid.guice.annotations
-
Binding annotation for implements of interfaces that are focused on running native queries.
- NATURAL - Static variable in class org.apache.druid.query.ordering.StringComparators
- NATURAL_CACHE_ID - Static variable in class org.apache.druid.query.ordering.StringComparators
- NATURAL_NAME - Static variable in class org.apache.druid.query.ordering.StringComparators
- NaturalComparator() - Constructor for class org.apache.druid.query.ordering.StringComparators.NaturalComparator
- naturalNullsFirst() - Static method in class org.apache.druid.java.util.common.guava.Comparators
- needConversion(int) - Method in class org.apache.druid.segment.DictionaryMergingIterator
- NEEDS_APPLIED - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression must be implicitly mapped across the multiple values per row of known multi-value inputs, the final output will be multi-valued
- needsDeterminePartitions(boolean) - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- needsDeterminePartitions(boolean) - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- needsDeterminePartitions(boolean) - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- needsDeterminePartitions(boolean) - Method in interface org.apache.druid.indexer.partitions.PartitionsSpec
-
Returns true if this partitionsSpec needs to determine the number of partitions to start data ingestion.
- needsFormat() - Method in class org.apache.druid.data.input.impl.CloudObjectInputSource
- needsFormat() - Method in class org.apache.druid.data.input.impl.CombiningInputSource
- needsFormat() - Method in class org.apache.druid.data.input.impl.HttpInputSource
- needsFormat() - Method in class org.apache.druid.data.input.impl.InlineInputSource
- needsFormat() - Method in class org.apache.druid.data.input.impl.LocalInputSource
- needsFormat() - Method in interface org.apache.druid.data.input.InputSource
-
Returns true if this inputSource supports different
InputFormat
s. - needSorting() - Method in enum org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
- needsToProcessHeaderLine() - Method in class org.apache.druid.data.input.impl.DelimitedValueReader
- needsToProcessHeaderLine() - Method in class org.apache.druid.data.input.impl.JsonLineReader
- needsToProcessHeaderLine() - Method in class org.apache.druid.data.input.impl.RegexReader
- needsToProcessHeaderLine() - Method in class org.apache.druid.data.input.TextReader
-
Returns true if the file format needs to process a header line.
- needToSplit(Node) - Method in class org.apache.druid.collections.spatial.split.GutmanSplitStrategy
- needToSplit(Node) - Method in interface org.apache.druid.collections.spatial.split.SplitStrategy
- negate(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- NEQ - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- NEQ - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- NESTED_DATA - Static variable in class org.apache.druid.math.expr.ExpressionType
- NESTED_DATA - Static variable in class org.apache.druid.segment.column.ColumnType
- NESTED_FIELD_PREFIX - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- NESTED_FIELD_PREFIX - Static variable in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- NestedColumnFormatV4() - Constructor for class org.apache.druid.segment.nested.NestedDataComplexTypeSerde.NestedColumnFormatV4
- NestedColumnMergable(SortedValueDictionary, SortedMap<String, FieldTypeInfo.MutableTypeSet>, boolean, boolean, Object) - Constructor for class org.apache.druid.segment.IndexableAdapter.NestedColumnMergable
- NestedColumnV4HandlerProvider() - Constructor for class org.apache.druid.guice.NestedDataModule.NestedColumnV4HandlerProvider
- NestedCommonFormatColumn - Interface in org.apache.druid.segment.nested
-
Base implementation for columns created with
AutoTypeColumnSchema
and handled withNestedCommonFormatColumnHandler
to allow ease of merge viaAutoTypeColumnMerger
by providing a common implementation. - NestedCommonFormatColumn.Format - Class in org.apache.druid.segment.nested
- NestedCommonFormatColumnHandler - Class in org.apache.druid.segment
- NestedCommonFormatColumnHandler(String, ColumnType) - Constructor for class org.apache.druid.segment.NestedCommonFormatColumnHandler
- NestedCommonFormatColumnPartSerde - Class in org.apache.druid.segment.serde
-
ColumnPartSerde
shared by allNestedCommonFormatColumn
. - NestedCommonFormatColumnPartSerde.SerializerBuilder - Class in org.apache.druid.segment.serde
- NestedCommonFormatColumnSerializer - Class in org.apache.druid.segment.nested
-
Basic serializer implementation for the
NestedCommonFormatColumn
family of columns. - NestedCommonFormatColumnSerializer() - Constructor for class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- NestedCommonFormatHandlerProvider() - Constructor for class org.apache.druid.guice.NestedDataModule.NestedCommonFormatHandlerProvider
- NestedDataColumnHandlerV4 - Class in org.apache.druid.segment
- NestedDataColumnHandlerV4(String) - Constructor for class org.apache.druid.segment.NestedDataColumnHandlerV4
- NestedDataColumnIndexerV4 - Class in org.apache.druid.segment
- NestedDataColumnIndexerV4() - Constructor for class org.apache.druid.segment.NestedDataColumnIndexerV4
- NestedDataColumnMergerV4 - Class in org.apache.druid.segment
- NestedDataColumnMergerV4(String, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.NestedDataColumnMergerV4
- NestedDataColumnMetadata - Class in org.apache.druid.segment.nested
- NestedDataColumnMetadata(ByteOrder, BitmapSerdeFactory, String, Boolean) - Constructor for class org.apache.druid.segment.nested.NestedDataColumnMetadata
- NestedDataColumnSchema - Class in org.apache.druid.segment
-
Nested column
DimensionSchema
. - NestedDataColumnSchema(String, int) - Constructor for class org.apache.druid.segment.NestedDataColumnSchema
- NestedDataColumnSchema(String, Integer, DefaultColumnFormatConfig) - Constructor for class org.apache.druid.segment.NestedDataColumnSchema
- NestedDataColumnSerializer - Class in org.apache.druid.segment.nested
-
Serializer for
NestedCommonFormatColumn
which can store nested data. - NestedDataColumnSerializer(String, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.nested.NestedDataColumnSerializer
- NestedDataColumnSerializerV4 - Class in org.apache.druid.segment.nested
- NestedDataColumnSerializerV4(String, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- NestedDataColumnSupplier - Class in org.apache.druid.segment.nested
- NestedDataColumnSupplierV4 - Class in org.apache.druid.segment.nested
- NestedDataColumnV3<TStringDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.nested
- NestedDataColumnV3(String, ColumnType, ColumnConfig, CompressedVariableSizedBlobColumnSupplier, ImmutableBitmap, GenericIndexed<String>, FieldTypeInfo, Supplier<TStringDictionary>, Supplier<FixedIndexed<Long>>, Supplier<FixedIndexed<Double>>, SmooshedFileMapper, BitmapSerdeFactory, ByteOrder) - Constructor for class org.apache.druid.segment.nested.NestedDataColumnV3
- NestedDataColumnV4<TStringDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.nested
- NestedDataColumnV4(String, ColumnType, ColumnConfig, CompressedVariableSizedBlobColumnSupplier, ImmutableBitmap, GenericIndexed<String>, FieldTypeInfo, Supplier<TStringDictionary>, Supplier<FixedIndexed<Long>>, Supplier<FixedIndexed<Double>>, SmooshedFileMapper, BitmapSerdeFactory, ByteOrder) - Constructor for class org.apache.druid.segment.nested.NestedDataColumnV4
- NestedDataColumnV5<TStringDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.nested
-
Nested data column with optimized support for simple arrays.
- NestedDataColumnV5(String, ColumnType, ColumnConfig, CompressedVariableSizedBlobColumnSupplier, ImmutableBitmap, GenericIndexed<String>, FieldTypeInfo, Supplier<TStringDictionary>, Supplier<FixedIndexed<Long>>, Supplier<FixedIndexed<Double>>, Supplier<FrontCodedIntArrayIndexed>, SmooshedFileMapper, BitmapSerdeFactory, ByteOrder) - Constructor for class org.apache.druid.segment.nested.NestedDataColumnV5
- NestedDataComplexColumn - Class in org.apache.druid.segment.nested
-
Describes the basic shape for any 'nested data' (
StructuredData
)ComplexColumn
implementation along with basic facilities for caching any columns created and methods for retrieving selectors for nested field columns. - NestedDataComplexColumn() - Constructor for class org.apache.druid.segment.nested.NestedDataComplexColumn
- NestedDataComplexTypeSerde - Class in org.apache.druid.segment.nested
- NestedDataComplexTypeSerde() - Constructor for class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- NestedDataComplexTypeSerde.NestedColumnFormatV4 - Class in org.apache.druid.segment.nested
- NestedDataExpressions - Class in org.apache.druid.query.expression
- NestedDataExpressions() - Constructor for class org.apache.druid.query.expression.NestedDataExpressions
- NestedDataExpressions.JsonKeysExprMacro - Class in org.apache.druid.query.expression
- NestedDataExpressions.JsonObjectExprMacro - Class in org.apache.druid.query.expression
- NestedDataExpressions.JsonPathsExprMacro - Class in org.apache.druid.query.expression
- NestedDataExpressions.JsonQueryArrayExprMacro - Class in org.apache.druid.query.expression
- NestedDataExpressions.JsonQueryExprMacro - Class in org.apache.druid.query.expression
- NestedDataExpressions.JsonValueExprMacro - Class in org.apache.druid.query.expression
- NestedDataExpressions.ParseJsonExprMacro - Class in org.apache.druid.query.expression
- NestedDataExpressions.ToJsonStringExprMacro - Class in org.apache.druid.query.expression
- NestedDataExpressions.TryParseJsonExprMacro - Class in org.apache.druid.query.expression
- NestedDataModule - Class in org.apache.druid.guice
- NestedDataModule() - Constructor for class org.apache.druid.guice.NestedDataModule
- NestedDataModule.NestedColumnV4HandlerProvider - Class in org.apache.druid.guice
- NestedDataModule.NestedCommonFormatHandlerProvider - Class in org.apache.druid.guice
- NestedDataModule.SideEffectHandlerRegisterer - Class in org.apache.druid.guice
-
this is used as a vehicle to register the correct version of the system default nested column handler by side effect with the help of binding to
Lifecycle
so thatNestedDataModule.registerHandler(DefaultColumnFormatConfig)
can be called with the injectedDefaultColumnFormatConfig
. - NestedDataParseSpec<TFlattenSpec> - Class in org.apache.druid.data.input.impl
- NestedDataParseSpec(TimestampSpec, DimensionsSpec, TFlattenSpec) - Constructor for class org.apache.druid.data.input.impl.NestedDataParseSpec
- NestedExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.NestedExprContext
- NestedFieldColumnIndexSupplier<TStringDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.nested
-
Supplies indexes for nested field columns
NestedFieldDictionaryEncodedColumn
ofNestedDataComplexColumn
. - NestedFieldColumnIndexSupplier(FieldTypeInfo.TypeSet, BitmapFactory, ColumnConfig, GenericIndexed<ImmutableBitmap>, Supplier<FixedIndexed<Integer>>, Supplier<TStringDictionary>, Supplier<FixedIndexed<Long>>, Supplier<FixedIndexed<Double>>, Supplier<FrontCodedIntArrayIndexed>, Supplier<FixedIndexed<Integer>>, GenericIndexed<ImmutableBitmap>) - Constructor for class org.apache.druid.segment.nested.NestedFieldColumnIndexSupplier
- NestedFieldDictionaryEncodedColumn<TStringDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.nested
- NestedFieldDictionaryEncodedColumn(FieldTypeInfo.TypeSet, ColumnarLongs, ColumnarDoubles, ColumnarInts, TStringDictionary, FixedIndexed<Long>, FixedIndexed<Double>, FrontCodedIntArrayIndexed, FixedIndexed<Integer>, ImmutableBitmap) - Constructor for class org.apache.druid.segment.nested.NestedFieldDictionaryEncodedColumn
- NestedFieldVirtualColumn - Class in org.apache.druid.segment.virtual
-
Optimized virtual column that can make direct selectors into a
NestedDataComplexColumn
or any associated nested fields (NestedFieldDictionaryEncodedColumn
) including using their indexes. - NestedFieldVirtualColumn(String, String, String) - Constructor for class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- NestedFieldVirtualColumn(String, String, String, ColumnType) - Constructor for class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- NestedFieldVirtualColumn(String, String, ColumnType, List<NestedPathPart>, Boolean, String, Boolean) - Constructor for class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- NestedFieldVirtualColumn.FieldDimensionSelector - Class in org.apache.druid.segment.virtual
- NestedFieldVirtualColumn.RawFieldColumnSelector - Class in org.apache.druid.segment.virtual
-
Process the "raw" data to extract values with
NestedPathFinder.find(Object, List)
, wrapping the result inStructuredData
- NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector - Class in org.apache.druid.segment.virtual
-
Process the "raw" data to extract non-complex values.
- NestedFieldVirtualColumn.RawFieldVectorObjectSelector - Class in org.apache.druid.segment.virtual
-
Process the "raw" data to extract vectors of values with
NestedPathFinder.find(Object, List)
, wrapping the result inStructuredData
- NestedInputFormat - Class in org.apache.druid.data.input.impl
-
Abstract class for nested file formats such as JSON, ORC, etc.
- NestedInputFormat(JSONPathSpec) - Constructor for class org.apache.druid.data.input.impl.NestedInputFormat
- NestedPathArrayElement - Class in org.apache.druid.segment.nested
- NestedPathArrayElement(int) - Constructor for class org.apache.druid.segment.nested.NestedPathArrayElement
- NestedPathField - Class in org.apache.druid.segment.nested
- NestedPathField(String) - Constructor for class org.apache.druid.segment.nested.NestedPathField
- NestedPathFinder - Class in org.apache.druid.segment.nested
- NestedPathFinder() - Constructor for class org.apache.druid.segment.nested.NestedPathFinder
- NestedPathPart - Interface in org.apache.druid.segment.nested
- NettyHttpClient - Class in org.apache.druid.java.util.http.client
-
Implementation of
HttpClient
built using Netty. - 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
- newAllocator() - Method in class org.apache.druid.frame.allocation.ArenaMemoryAllocatorFactory
- newAllocator() - Method in interface org.apache.druid.frame.allocation.MemoryAllocatorFactory
-
Returns a new allocator with capacity
MemoryAllocatorFactory.allocatorCapacity()
. - newAllocator() - Method in class org.apache.druid.frame.allocation.SingleMemoryAllocatorFactory
- newBlockingSingleThreaded(String, int) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- newBlockingSingleThreaded(String, int, Integer) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- newBlockingThreaded(String, int, int) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- newBlockingThreaded(String, int, int, Integer) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- 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
- newFirstValue() - Method in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
- newFrameFileReference() - Method in class org.apache.druid.frame.channel.ReadableFileFrameChannel
-
Returns a new reference to the
FrameFile
that this channel is reading from. - newFrameWriter(ColumnSelectorFactory) - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriterFactory
- newFrameWriter(ColumnSelectorFactory) - Method in interface org.apache.druid.frame.write.FrameWriterFactory
-
Create a writer where
FrameWriter.addSelection()
adds the current row from aColumnSelectorFactory
. - newFrameWriter(ColumnSelectorFactory) - Method in class org.apache.druid.frame.write.RowBasedFrameWriterFactory
- newImmutableFromMutable(RTree) - Static method in class org.apache.druid.collections.spatial.ImmutableRTree
- newImmutableFromMutable(ConciseSet) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- NEWLINES - org.apache.druid.java.util.emitter.core.BatchingStrategy
- newLinkedHashMapWithExpectedSize(int) - Static method in class org.apache.druid.utils.CollectionUtils
-
Returns a LinkedHashMap with an appropriate size based on the callers expectedSize.
- newReference() - Method in class org.apache.druid.frame.file.FrameFile
-
Creates a new reference to this file.
- 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
- NewSpatialDimensionSchema - Class in org.apache.druid.data.input.impl
-
NOTE: This class should be deprecated after Druid supports configurable index types on dimensions.
- NewSpatialDimensionSchema(String, List<String>) - Constructor for class org.apache.druid.data.input.impl.NewSpatialDimensionSchema
- newTaskFor(Runnable, T) - Method in class org.apache.druid.query.PrioritizedExecutorService
- newTaskFor(Callable<T>) - Method in class org.apache.druid.query.PrioritizedExecutorService
- newTaskId(String, String, String, Interval) - Static method in class org.apache.druid.common.utils.IdUtils
- newTaskId(String, String, Interval) - Static method in class org.apache.druid.common.utils.IdUtils
- newTimeBoundaryQueryBuilder() - Static method in class org.apache.druid.query.Druids
- newTimeseriesQueryBuilder() - Static method in class org.apache.druid.query.Druids
- newTreeSet(Comparator<? super E>, Iterable<E>) - Static method in class org.apache.druid.utils.CollectionUtils
- newWordIterator() - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- next() - Method in class org.apache.druid.collections.bitmap.PeekableIteratorAdapter
- next() - Method in class org.apache.druid.collections.CombiningIterator
- next() - Method in class org.apache.druid.collections.IntegerSet.BitSetIterator
- next() - Method in class org.apache.druid.data.input.HandlingInputRowIterator
- next() - Method in class org.apache.druid.data.input.impl.FastLineIterator
- next() - Method in class org.apache.druid.data.input.impl.prefetch.JsonIterator
-
Retrieves the next deserialized object from the stream of JSON objects.
- next() - Method in class org.apache.druid.extendedset.intset.BitIterator
- next() - Method in class org.apache.druid.extendedset.intset.EmptyIntIterator
- next() - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet.WordIterator
- next() - Method in interface org.apache.druid.extendedset.intset.IntSet.IntIterator
- next() - Method in class org.apache.druid.frame.channel.FrameChannelSequence.FrameChannelIterator
- next() - Method in class org.apache.druid.frame.processor.manager.AccumulatingProcessorManager
- next() - Method in interface org.apache.druid.frame.processor.manager.ProcessorManager
-
Returns the next processor that should be run, along with a callback.
- next() - Method in class org.apache.druid.frame.processor.manager.SequenceProcessorManager
- next() - Method in class org.apache.druid.java.util.common.guava.DroppingIterator
- next() - Method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- next() - Method in class org.apache.druid.java.util.common.guava.MergeIterator
- next() - Method in class org.apache.druid.java.util.common.guava.nary.TrinaryTransformIterator
- 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.query.scan.ScanResultValueIterator
- next() - Method in class org.apache.druid.segment.AutoTypeColumnMerger.ArrayDictionaryMergingIterator
- next() - Method in class org.apache.druid.segment.AutoTypeColumnMerger.IdLookupArrayIterator
- next() - Method in class org.apache.druid.segment.DictionaryMergingIterator
- next() - Method in interface org.apache.druid.segment.serde.cell.IOIterator
- next() - Method in class org.apache.druid.segment.SimpleDictionaryMergingIterator
- next(T) - Method in class org.apache.druid.java.util.common.guava.ExecuteWhenDoneYielder
- next(T) - Method in interface org.apache.druid.java.util.common.guava.Yielder
-
Gets the next Yielder in the chain.
- nextAfter(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- NextAfter() - Constructor for class org.apache.druid.math.expr.Function.NextAfter
- nextBatch(int[]) - Method in class org.apache.druid.collections.bitmap.BatchIteratorAdapter
- nextCount(long) - Static method in class org.apache.druid.concurrent.ConcurrentAwaitableCounter
-
This method should be called to obtain the next total increment count to be passed to
ConcurrentAwaitableCounter.awaitCount(long)
methods, instead of just adding 1 to the previous count, because the count must wrap aroundLong.MAX_VALUE
and start from 0 again. - 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
- nextRaw() - Method in class org.apache.druid.segment.generator.DataGenerator
- nextRaw(String) - Method in class org.apache.druid.segment.generator.DataGenerator
- nextRetrySleepMillis(int) - Static method in class org.apache.druid.java.util.common.RetryUtils
- nextRow() - Method in interface org.apache.druid.data.input.Firehose
-
Deprecated.The next row available.
- nextRow() - Method in class org.apache.druid.segment.generator.DataGenerator
- nextRowWithRaw() - Method in interface org.apache.druid.data.input.Firehose
-
Deprecated.
- nextUp(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- NextUp() - Constructor for class org.apache.druid.math.expr.Function.NextUp
- nil() - Static method in class org.apache.druid.math.expr.ExprMacroTable
- nil(int) - Static method in class org.apache.druid.frame.processor.OutputChannel
-
Create a nil output channel, representing a processor that writes nothing.
- NIL_COLUMN_CAPABILITIES - Static variable in class org.apache.druid.segment.ColumnProcessors
-
Capabilites that are used when we return a nil selector for a nonexistent column.
- NIL_VECTOR_AGGREGATOR - Static variable in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- nilBindings() - Static method in class org.apache.druid.math.expr.InputBindings
-
Empty
Expr.ObjectBinding
that doesn't complain about attempts to access type or value for any input identifiers, both of which will be nulls. - NilColumnValueSelector - Class in org.apache.druid.segment
-
Represents "absent" column.
- NilGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
-
Treats all rows as null.
- nilSelector() - Static method in interface org.apache.druid.segment.DimensionSelector
- NilStorageConnector - Class in org.apache.druid.storage
- NilVectorAggregator - Class in org.apache.druid.query.aggregation.any
-
A vector aggregator that returns the default numeric value.
- NilVectorSelector - Class in org.apache.druid.segment.vector
- NO - org.apache.druid.segment.column.RowSignature.Finalization
-
Aggregation results will not be finalized.
- NO_BITMAP_INDEX - org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.Feature
- NO_FLAGS - Static variable in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
- NO_PARTITION - Static variable in class org.apache.druid.frame.channel.FrameWithPartition
- NO_PARTITION - Static variable in class org.apache.druid.frame.file.FrameFileWriter
- 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.
- NoErrorResponseTransformStrategy - Class in org.apache.druid.common.exception
-
Error response transform strategy that does nothing and simply return the same Exception back without any change
- NoErrorResponseTransformStrategy() - Constructor for class org.apache.druid.common.exception.NoErrorResponseTransformStrategy
- NoFilterVectorOffset - Class in org.apache.druid.segment.vector
- NoFilterVectorOffset(int, int, int) - Constructor for class org.apache.druid.segment.vector.NoFilterVectorOffset
- NoIndexesColumnIndexSupplier - Class in org.apache.druid.segment.serde
-
Default implementation of
ColumnIndexSupplier
for columns which do not have any indexes. - NoIndexesColumnIndexSupplier() - Constructor for class org.apache.druid.segment.serde.NoIndexesColumnIndexSupplier
- NON_NULL_ELEMENT_MARKER - Static variable in class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
- NON_NULL_ROW - Static variable in class org.apache.druid.frame.field.NumericArrayFieldWriter
-
Denotes that the array is non null
- NON_ROOT_GEN_END_PARTITION_ID - Static variable in class org.apache.druid.timeline.partition.PartitionIds
-
End partitionId available for non-root generation segments.
- NON_ROOT_GEN_START_PARTITION_ID - Static variable in class org.apache.druid.timeline.partition.PartitionIds
-
Start partitionId available for non-root generation segments.
- NON_SCALAR_INPUTS - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression explicitly using multi-valued inputs as array inputs or has array inputs
- NON_SCALAR_OUTPUT - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression produces explict multi-valued output
- NonBlockingPool<T> - Interface in org.apache.druid.collections
- none() - Static method in class org.apache.druid.data.input.impl.systemfield.SystemFields
- none() - Static method in class org.apache.druid.frame.key.ClusterBy
-
Create an empty key.
- none() - Static method in class org.apache.druid.frame.processor.manager.ProcessorManagers
-
Manager with zero processors.
- none() - Static method in class org.apache.druid.frame.processor.OutputChannels
- NONE - org.apache.druid.frame.key.KeyOrder
-
Not ordered.
- NONE - org.apache.druid.indexer.RunnerTaskState
- NONE - org.apache.druid.java.util.common.granularity.GranularityType
- NONE - org.apache.druid.query.scan.ScanQuery.Order
- NONE - org.apache.druid.segment.data.CompressionStrategy
-
This value indicate no compression strategy should be used, and compression should not be block based.
- NONE - Static variable in class org.apache.druid.data.input.impl.systemfield.SystemFieldDecoratorFactory
-
Decorator factory that does not generate system fields.
- NONE - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- NONE - Static variable in class org.apache.druid.query.operator.OffsetLimit
- NONE - Static variable in class org.apache.druid.segment.transform.TransformSpec
- NONE - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- NoneColumnIncluderator - Class in org.apache.druid.query.metadata.metadata
- NoneColumnIncluderator() - Constructor for class org.apache.druid.query.metadata.metadata.NoneColumnIncluderator
- NoneGranularity - Class in org.apache.druid.java.util.common.granularity
-
NoneGranularity does not bucket data
- NoneGranularity() - Constructor for class org.apache.druid.java.util.common.granularity.NoneGranularity
-
This constructor is public b/c it is serialized and deserialized based on type in GranularityModule
- NoneShardSpec - Class in org.apache.druid.timeline.partition
-
Deprecated.Since Druid 0.15.0. Segments generated by Druid 0.15.0 onwards do not use this shard spec.
- NonnullPair<L,R> - Class in org.apache.druid.java.util.common
- NonnullPair(L, R) - Constructor for class org.apache.druid.java.util.common.NonnullPair
- noNoneValues() - Static method in enum org.apache.druid.segment.data.CompressionStrategy
- nonStrictFormat(String, Object...) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Formats the string as
StringUtils.format(String, Object...)
, but instead of failing on illegal format, returns the concatenated format string and format arguments. - NOOP - Static variable in interface org.apache.druid.segment.SegmentLazyLoadFailCallback
- NoopAggregator - Class in org.apache.druid.query.aggregation
- NoopBufferAggregator - Class in org.apache.druid.query.aggregation
- NoopDataSegmentPusher - Class in org.apache.druid.segment.loading
-
Mostly used for test purpose.
- NoopDataSegmentPusher() - Constructor for class org.apache.druid.segment.loading.NoopDataSegmentPusher
- NoopEmitter - Class in org.apache.druid.java.util.emitter.core
- NoopEmitter() - Constructor for class org.apache.druid.java.util.emitter.core.NoopEmitter
- NoopEmitterFactory - Class in org.apache.druid.java.util.emitter.factory
- NoopEmitterFactory() - Constructor for class org.apache.druid.java.util.emitter.factory.NoopEmitterFactory
- NoopInputRowParser - Class in org.apache.druid.data.input.impl
- NoopInputRowParser(ParseSpec) - Constructor for class org.apache.druid.data.input.impl.NoopInputRowParser
- NoopJoinableFactory - Class in org.apache.druid.segment.join
- NoopJoinableFactory() - Constructor for class org.apache.druid.segment.join.NoopJoinableFactory
- NoopLimitSpec - Class in org.apache.druid.query.groupby.orderby
- NoopOshiSysMonitor - Class in org.apache.druid.java.util.metrics
- NoopOshiSysMonitor() - Constructor for class org.apache.druid.java.util.metrics.NoopOshiSysMonitor
- 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
- NoopSysMonitor - Class in org.apache.druid.java.util.metrics
- NoopSysMonitor() - Constructor for class org.apache.druid.java.util.metrics.NoopSysMonitor
- NoopTaskLogs - Class in org.apache.druid.tasklogs
- NoopTaskLogs() - Constructor for class org.apache.druid.tasklogs.NoopTaskLogs
- NoopVectorAggregator - Class in org.apache.druid.query.aggregation
- NORMAL - org.apache.druid.java.util.common.lifecycle.Lifecycle.Stage
- NORMAL - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- noStackTrace() - Method in class org.apache.druid.java.util.common.logger.Logger
-
Returns a copy of this Logger that does not log exception stack traces, unless the log level is DEBUG or lower.
- noStackTrace() - Method in class org.apache.druid.java.util.emitter.EmittingLogger
- not(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Creates an
ExprVectorProcessor
for the logical 'not' operator, which produces a long typed vector output with values set by the following rules: false -> true (1) null -> null true -> false (0) - not(DimFilter) - Static method in class org.apache.druid.query.filter.DimFilters
- NOT - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- NOT - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- NOT_EXIST - Static variable in interface org.apache.druid.segment.DictionaryEncodedColumnMerger.IndexSeeker
- NOT_FOUND - org.apache.druid.error.DruidException.Category
-
Means that the requsted requested resource cannot be found.
- NOT_FOUND - Static variable in interface org.apache.druid.segment.join.table.IndexedTable.Index
- NOT_INIT - Static variable in interface org.apache.druid.segment.DictionaryEncodedColumnMerger.IndexSeeker
- NOT_NULL_BYTE - Static variable in class org.apache.druid.frame.field.ComplexFieldWriter
- NOT_NULL_BYTE - Static variable in class org.apache.druid.frame.field.NumericFieldWriter
-
Indicator byte denoting that the numeric value succeeding it is not null.
- NOT_NULL_BYTE - Static variable in class org.apache.druid.frame.field.StringFieldWriter
- NOT_NULL_MARKER - Static variable in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- NOT_STARTED - org.apache.druid.indexer.IngestionState
- NotDimFilter - Class in org.apache.druid.query.filter
- NotDimFilter(DimFilter) - Constructor for class org.apache.druid.query.filter.NotDimFilter
- notEqual(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorComparisonProcessors
- notEqualTo(T) - Static method in interface org.apache.druid.query.filter.DruidObjectPredicate
- NotFilter - Class in org.apache.druid.segment.filter
-
Nice filter you have there...
- NotFilter(Filter) - Constructor for class org.apache.druid.segment.filter.NotFilter
- notFound(int) - Static method in class org.apache.druid.query.rowsandcols.util.FindResult
- NotFound - Class in org.apache.druid.error
- NotFound(Throwable, String, Object...) - Constructor for class org.apache.druid.error.NotFound
- 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
- NotImplementedMappingProvider - Class in org.apache.druid.java.util.common.parsers
- NotImplementedMappingProvider() - Constructor for class org.apache.druid.java.util.common.parsers.NotImplementedMappingProvider
- notNull() - Static method in interface org.apache.druid.query.filter.DruidObjectPredicate
- nowUtc() - Static method in class org.apache.druid.java.util.common.DateTimes
- NULL - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- NULL - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- NULL() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LiteralElementContext
- NULL() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LongElementContext
- NULL() - Method in class org.apache.druid.math.expr.antlr.ExprParser.NullContext
- NULL() - Method in class org.apache.druid.math.expr.antlr.ExprParser.NumericElementContext
- NULL() - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringElementContext
- NULL_BITMAP_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- NULL_BITMAP_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- NULL_BYTE - Static variable in class org.apache.druid.frame.field.ComplexFieldWriter
- NULL_BYTE - Static variable in class org.apache.druid.frame.field.NumericFieldWriter
-
Indicator byte denoting that the numeric value succeeding it is null.
- NULL_BYTE - Static variable in class org.apache.druid.frame.field.StringFieldWriter
-
Different from the values in
NullHandling
, since we want to be able to sort as bytes, and we want nulls to come before non-nulls. - NULL_ELEMENT_MARKER - Static variable in class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
- NULL_HANDLING_CONFIG_STRING - Static variable in class org.apache.druid.common.config.NullValueHandlingConfig
- NULL_HANDLING_DURING_STRING_CARDINALITY - Static variable in class org.apache.druid.common.config.NullValueHandlingConfig
- NULL_HANDLING_LEGACY_LOGICAL_OPS_STRING - Static variable in class org.apache.druid.math.expr.ExpressionProcessingConfig
- NULL_ID - Static variable in interface org.apache.druid.segment.vector.ReadableVectorInspector
-
A marker value that will never be returned by "getId".
- NULL_LITERAL - Static variable in interface org.apache.druid.math.expr.Expr
- NULL_LITERAL - Static variable in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessedValue
- NULL_MARKER - Static variable in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- NULL_ROW - Static variable in class org.apache.druid.frame.field.NumericArrayFieldWriter
-
Denotes that the array itself is null
- NULL_ROW - Static variable in class org.apache.druid.frame.field.StringFieldWriter
-
Null rows are represented by
NULL_ROW
. - NULL_STRING_MARKER - Static variable in class org.apache.druid.frame.write.FrameWriterUtils
- NULL_STRING_MARKER_ARRAY - Static variable in class org.apache.druid.frame.write.FrameWriterUtils
- NULLABLE_DOUBLE_SIZE - Static variable in class org.apache.druid.segment.column.TypeStrategies
- NULLABLE_FLOAT_SIZE - Static variable in class org.apache.druid.segment.column.TypeStrategies
- NULLABLE_LONG_SIZE - Static variable in class org.apache.druid.segment.column.TypeStrategies
- NullableDoubleGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
- NullableFloatGroupByVectorColumnSelector - Class in org.apache.druid.query.groupby.epinephelinae.vector
- nullableListOf(T...) - Static method in class org.apache.druid.java.util.common.collect.Utils
- 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
- NullableNumericTopNColumnAggregatesProcessor<Selector extends BaseNullableColumnValueSelector> - Class in org.apache.druid.query.topn.types
- NullableNumericTopNColumnAggregatesProcessor(Function<Object, Object>) - 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.
- NullableTypeStrategy<T> - Class in org.apache.druid.segment.column
-
Wrapper of
TypeStrategy
for nullable types, which storesNullHandling.IS_NULL_BYTE
orNullHandling.IS_NOT_NULL_BYTE
in the leading byte of any value, as appropriate. - NullableTypeStrategy(TypeStrategy<T>) - Constructor for class org.apache.druid.segment.column.NullableTypeStrategy
- NullColumn - Class in org.apache.druid.query.rowsandcols.column
- NullColumn(ColumnType, int) - Constructor for class org.apache.druid.query.rowsandcols.column.NullColumn
- NullColumn.Accessor - Class in org.apache.druid.query.rowsandcols.column
- NullColumnPartSerde - Class in org.apache.druid.segment.serde
-
A ColumnPartSerde to read and write null-only columns.
- NullColumnPartSerde(int, BitmapSerdeFactory) - Constructor for class org.apache.druid.segment.serde.NullColumnPartSerde
- NullContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.NullContext
- NullDimensionSelectorHolder() - Constructor for class org.apache.druid.segment.DimensionSelector.NullDimensionSelectorHolder
- NullFilter - Class in org.apache.druid.query.filter
- NullFilter(String, FilterTuning) - Constructor for class org.apache.druid.query.filter.NullFilter
- NullFilter.NullPredicateFactory - Class in org.apache.druid.query.filter
- NullHandling - Class in org.apache.druid.common.config
-
Helper class for NullHandling.
- NullHandling() - Constructor for class org.apache.druid.common.config.NullHandling
- NullHandlingModule - Class in org.apache.druid.guice
- NullHandlingModule() - Constructor for class org.apache.druid.guice.NullHandlingModule
- NULLITY_OFFSET - Static variable in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
- nullMatcher(VectorValueSelector) - Static method in interface org.apache.druid.query.filter.vector.VectorValueMatcher
-
Make a
VectorValueMatcher
that only selects input rows with null values - nullRowsBitmap - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- NULLSTRING - org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
- nullToAll(Granularity) - Static method in class org.apache.druid.java.util.common.granularity.Granularities
- nullToEmpty(VirtualColumns) - Static method in class org.apache.druid.segment.VirtualColumns
- nullToEmptyIfNeeded(Double) - Static method in class org.apache.druid.common.config.NullHandling
- nullToEmptyIfNeeded(Float) - Static method in class org.apache.druid.common.config.NullHandling
- nullToEmptyIfNeeded(Long) - Static method in class org.apache.druid.common.config.NullHandling
- nullToEmptyIfNeeded(String) - Static method in class org.apache.druid.common.config.NullHandling
- nullToEmptyNonDruidDataString(String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Returns the given string if it is non-null; the empty string otherwise.
- 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(Float) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- nullToZero(Long) - 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
- NullValueHandlingConfig - Class in org.apache.druid.common.config
- NullValueHandlingConfig(Boolean, Boolean, Boolean) - Constructor for class org.apache.druid.common.config.NullValueHandlingConfig
- NullValueIndex - Interface in org.apache.druid.segment.index.semantic
-
Provides
BitmapColumnIndex
for all null rows in a column, to use with IS/IS NOT NULL filters - NullValueIndexSupplier - Class in org.apache.druid.segment.serde
-
ColumnIndexSupplier
for columns which only have anImmutableBitmap
to indicate which rows only have null values, such asLongNumericColumnPartSerdeV2
,DoubleNumericColumnPartSerdeV2
, andFloatNumericColumnPartSerdeV2
. - NullValueIndexSupplier(ImmutableBitmap) - Constructor for class org.apache.druid.segment.serde.NullValueIndexSupplier
- NUM_BUCKETS - Static variable in class org.apache.druid.hll.HyperLogLogCollector
- NUM_BYTES_FOR_BUCKETS - Static variable in class org.apache.druid.hll.HyperLogLogCollector
- NUM_BYTES_FOR_DENSE_STORAGE - Static variable in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- NUM_BYTES_FOR_DENSE_STORAGE - Static variable in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- NUM_NON_ZERO_REGISTERS_BYTE - Static variable in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- NUM_NON_ZERO_REGISTERS_BYTE - Static variable in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.Header: Byte 0: registerOffset Byte 1-2: numNonZeroRegisters
- NUM_REGIONS - Static variable in class org.apache.druid.frame.write.RowBasedFrameWriter
- NUM_RETRIES_ON_MISSING_SEGMENTS_KEY - Static variable in class org.apache.druid.query.QueryContexts
- NUM_SCANNED_ROWS - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
The number of rows scanned by
ScanQueryEngine
. - NUMBERED - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- NUMBERED_OVERWRITE - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- NumberedOverwritePartialShardSpec - Class in org.apache.druid.timeline.partition
- NumberedOverwritePartialShardSpec(int, int, int) - Constructor for class org.apache.druid.timeline.partition.NumberedOverwritePartialShardSpec
- NumberedOverwritePartialShardSpec(int, int, short) - Constructor for class org.apache.druid.timeline.partition.NumberedOverwritePartialShardSpec
- NumberedOverwriteShardSpec - Class in org.apache.druid.timeline.partition
-
This shardSpec is used only for the segments created by overwriting tasks with segment lock enabled.
- NumberedOverwriteShardSpec(int, int, int, short) - Constructor for class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- NumberedOverwriteShardSpec(int, int, int, short, short) - Constructor for class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- NumberedOverwritingPartitionChunk<T> - Class in org.apache.druid.timeline.partition
-
PartitionChunk corresponding to
NumberedOverwriteShardSpec
- NumberedOverwritingPartitionChunk(int, T) - Constructor for class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- NumberedPartialShardSpec - Class in org.apache.druid.timeline.partition
- NumberedPartitionChunk<T> - Class in org.apache.druid.timeline.partition
- NumberedPartitionChunk(int, int, T) - Constructor for class org.apache.druid.timeline.partition.NumberedPartitionChunk
- NumberedShardSpec - Class in org.apache.druid.timeline.partition
-
An extendable linear shard spec containing the information of core partitions.
- NumberedShardSpec(int, int) - Constructor for class org.apache.druid.timeline.partition.NumberedShardSpec
- Numbers - Class in org.apache.druid.java.util.common
- NumberSerializer - Interface in org.apache.druid.segment.serde.cell
- numBuckets - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- numBuckets() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
-
Returns the number of buckets in this table.
- numBytes() - Method in class org.apache.druid.frame.Frame
- 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(ExpressionType, ExpressionType) - Static method in class org.apache.druid.math.expr.ExpressionTypeConversion
-
Default best effort numeric type conversion.
- 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
- NumericArrayFieldReader - Class in org.apache.druid.frame.field
-
Reader class for the fields written by
NumericArrayFieldWriter
. - NumericArrayFieldReader() - Constructor for class org.apache.druid.frame.field.NumericArrayFieldReader
- NumericArrayFieldSelector<ElementType extends Number> - Class in org.apache.druid.frame.field
-
Base implementation of the column value selector that the concrete numeric field reader implementations inherit from.
- NumericArrayFieldSelector(Memory, ReadableFieldPointer) - Constructor for class org.apache.druid.frame.field.NumericArrayFieldSelector
- NumericArrayFieldWriter - Class in org.apache.druid.frame.field
-
Writes the values of the type ARRAY
where X is a numeric type to row based frames. - NumericArrayFieldWriter(ColumnValueSelector, NumericFieldWriterFactory) - Constructor for class org.apache.druid.frame.field.NumericArrayFieldWriter
- NumericArrayFrameColumn(Frame, Memory, ColumnType) - Constructor for class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader.NumericArrayFrameColumn
- NumericArrayFrameColumnReader - Class in org.apache.druid.frame.read.columnar
-
Implementations of this class reads columns written by the corresponding implementations of
NumericArrayFrameColumnWriter
. - NumericArrayFrameColumnReader(byte, ColumnType, int) - Constructor for class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader
- NumericArrayFrameColumnReader.NumericArrayFrameColumn - Class in org.apache.druid.frame.read.columnar
- NumericArrayFrameColumnWriter - Class in org.apache.druid.frame.write.columnar
-
Parent class for the family of writers writing numeric arrays in columnar frames.
- NumericArrayFrameColumnWriter(ColumnValueSelector, MemoryAllocator, byte) - Constructor for class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
- 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
- numericElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser.DoubleArrayContext
- numericElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitLongArrayContext
- numericElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- numericElement(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.DoubleArrayContext
- numericElement(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.ExplicitLongArrayContext
- NumericElementContext(ParserRuleContext, int) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.NumericElementContext
- NumericFieldReader - Class in org.apache.druid.frame.field
-
Reads the fields created by the
NumericFieldWriter
. - NumericFieldReader(boolean) - Constructor for class org.apache.druid.frame.field.NumericFieldReader
- NumericFieldReader.Selector - Class in org.apache.druid.frame.field
-
Helper class which allows the inheritors to fetch the nullity of the field located at fieldPointer's position in the dataRegion.
- NumericFieldWriter - Class in org.apache.druid.frame.field
-
FieldWriter for numeric datatypes.
- NumericFieldWriter(BaseNullableColumnValueSelector, boolean) - Constructor for class org.apache.druid.frame.field.NumericFieldWriter
- NumericFieldWriterFactory - Interface in org.apache.druid.frame.field
-
Factory for
NumericFieldWriter
- numericFirst - org.apache.druid.query.aggregation.post.ArithmeticPostAggregator.Ordering
-
Ensures the following order: numeric > NaN > Infinite.
- numericFirst - org.apache.druid.query.aggregation.post.ExpressionPostAggregator.Ordering
-
Ensures the following order: numeric > NaN > Infinite.
- NumericFirstAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
-
Base type for on heap 'first' aggregator for primitive numeric column selectors
- NumericFirstAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.NumericFirstAggregator
- NumericFirstBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
-
Base type for buffer based 'first' aggregator for primitive numeric column selectors
- NumericFirstBufferAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.NumericFirstBufferAggregator
- NumericLastAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
-
Base type for on heap 'last' aggregator for primitive numeric column selectors..
- NumericLastAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.NumericLastAggregator
- NumericLastBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
-
Base type for buffer based 'last' aggregator for primitive numeric column selectors This could probably share a base type with
NumericFirstBufferAggregator
... - NumericLastBufferAggregator(BaseLongColumnValueSelector, ColumnValueSelector, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.NumericLastBufferAggregator
- NumericRangeIndexes - Interface in org.apache.druid.segment.index.semantic
-
An optimized column value
BitmapColumnIndex
provider for specialized processing of numeric value ranges. - NumericTopNMetricSpec - Class in org.apache.druid.query.topn
- NumericTopNMetricSpec(String) - Constructor for class org.apache.druid.query.topn.NumericTopNMetricSpec
- numFrames() - Method in class org.apache.druid.frame.file.FrameFile
-
Number of frames in the file.
- 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.
- numPartitions() - Method in class org.apache.druid.frame.file.FrameFile
-
Number of partitions in the file, or zero if the file is unpartitioned.
- numRegions() - Method in class org.apache.druid.frame.Frame
- numRows() - Method in class org.apache.druid.frame.Frame
- numRows() - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader.NumericArrayFrameColumn
- numRows() - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- numRows() - Method in class org.apache.druid.query.rowsandcols.AppendableMapOfColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- numRows() - Method in interface org.apache.druid.query.rowsandcols.column.ColumnAccessor
-
Get the number of rows
- numRows() - Method in class org.apache.druid.query.rowsandcols.column.NullColumn.Accessor
- numRows() - Method in class org.apache.druid.query.rowsandcols.ConcatRowsAndColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.concrete.ColumnBasedFrameRowsAndColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.concrete.QueryableIndexRowsAndColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.concrete.RowBasedFrameRowsAndColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.EmptyRowsAndColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.LazilyDecoratedRowsAndColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.LimitedRowsAndColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- numRows() - Method in class org.apache.druid.query.rowsandcols.RearrangedRowsAndColumns
- numRows() - Method in interface org.apache.druid.query.rowsandcols.RowsAndColumns
-
The number of rows in the RowsAndColumns object
- numRows() - Method in interface org.apache.druid.query.rowsandcols.semantic.SortedMatrixMaker.SortedMatrix
- numRows() - Method in class org.apache.druid.query.rowsandcols.StorageAdapterRowsAndColumns
- numRows() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
- numRows() - Method in class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- 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
- numRows(Segment) - Method in class org.apache.druid.query.metadata.SegmentAnalyzer
- 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. - nvl(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Creates an
ExprVectorProcessor
for the 'nvl' function, that will return the first argument value if it is not null, else the value of the 2nd argument. - NvlFunc() - Constructor for class org.apache.druid.math.expr.Function.NvlFunc
O
- OBJECT_MAPPER - Static variable in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- 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
- ObjectArrayColumn - Class in org.apache.druid.query.rowsandcols.column
- ObjectArrayColumn(Object[], ColumnType) - Constructor for class org.apache.druid.query.rowsandcols.column.ObjectArrayColumn
- ObjectArrayColumn(Object[], ColumnType, Comparator<Object>) - Constructor for class org.apache.druid.query.rowsandcols.column.ObjectArrayColumn
- objectAsBoolean(Object) - Static method in class org.apache.druid.math.expr.Evals
-
Best effort try to turn a value into a boolean:
Boolean
will be passed directly throughString
will useEvals.asBoolean(String)
Long
will useEvals.asBoolean(long)
Number
will useEvals.asBoolean(double)
everything else, including null will be false - ObjectBasedColumnSelector<T> - Class in org.apache.druid.segment
-
Object based column selector.
- ObjectBasedColumnSelector() - Constructor for class org.apache.druid.segment.ObjectBasedColumnSelector
- ObjectColumnAccessorBase - Class in org.apache.druid.query.rowsandcols.column.accessor
- ObjectColumnAccessorBase() - Constructor for class org.apache.druid.query.rowsandcols.column.accessor.ObjectColumnAccessorBase
- ObjectColumnSelector<T> - Class in org.apache.druid.segment
-
Restricts selector usage to only allow
BaseObjectColumnValueSelector.getObject()
. - 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.
- ObjectContainer(T, long) - Constructor for class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue.ObjectContainer
- ObjectFlattener<T> - Interface in org.apache.druid.java.util.common.parsers
- ObjectFlatteners - Class in org.apache.druid.java.util.common.parsers
- ObjectFlatteners.FlattenerMaker<T> - Interface in org.apache.druid.java.util.common.parsers
- objectOpenFunction(ObjectOpenFunction<T>) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- ObjectOpenFunction<T> - Interface in org.apache.druid.data.input.impl.prefetch
- ObjectOrErrorResponseHandler<IntermediateType,FinalType> - Class in org.apache.druid.java.util.http.client.response
-
Response handler that delegates successful responses (2xx response codes) to some other handler, but returns errors (non-2xx response codes) as Strings.
- ObjectOrErrorResponseHandler(HttpResponseHandler<IntermediateType, FinalType>) - Constructor for class org.apache.druid.java.util.http.client.response.ObjectOrErrorResponseHandler
- ObjectOutMultiObjectInVectorProcessor - Class in org.apache.druid.math.expr.vector
-
many strings enter, one string leaves...
- ObjectOutMultiObjectInVectorProcessor(ExprVectorProcessor<Object[]>[], int, ExpressionType) - Constructor for class org.apache.druid.math.expr.vector.ObjectOutMultiObjectInVectorProcessor
- ObjectOutObjectsInFunctionVectorProcessor - Class in org.apache.druid.math.expr.vector
- ObjectOutObjectsInFunctionVectorProcessor(ExprVectorProcessor<Object[]>, ExprVectorProcessor<Object[]>, int, ExpressionType) - Constructor for class org.apache.druid.math.expr.vector.ObjectOutObjectsInFunctionVectorProcessor
- objectsCreatedCount() - Method in class org.apache.druid.collections.StupidPool
- ObjectStrategy<T> - Interface in org.apache.druid.segment.data
- ObjectStrategyComplexTypeStrategy<T> - Class in org.apache.druid.segment.column
-
Default implementation of
TypeStrategy
for allComplexMetricSerde
implementations that just wraps theObjectStrategy
they are required to implement. - ObjectStrategyComplexTypeStrategy(ObjectStrategy<T>, TypeSignature<?>) - Constructor for class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- ObjectStrategyComplexTypeStrategy(ObjectStrategy<T>, TypeSignature<?>, Hash.Strategy<T>) - Constructor for class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- objectSupplier(ChunkingStorageConnector.GetObjectFromRangeFunction<T>) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- objectToNumber(String, Object, boolean) - Static method in class org.apache.druid.data.input.Rows
-
Shorthand for
Rows.objectToNumber(String, Object, ValueType, boolean)
with null expectedType. - objectToNumber(String, Object, ValueType, boolean) - Static method in class org.apache.druid.data.input.Rows
-
Convert an object to a number.
- objectToStrings(Object) - Static method in class org.apache.druid.data.input.Rows
-
Convert an object to a list of strings.
- ObjectVectorValueMatcher - Class in org.apache.druid.query.filter.vector
-
Generic object matcher on top of a
VectorObjectSelector
. - ObjectVectorValueMatcher(VectorObjectSelector) - Constructor for class org.apache.druid.query.filter.vector.ObjectVectorValueMatcher
- of(boolean) - Static method in enum org.apache.druid.query.filter.DruidPredicateMatch
- of(boolean) - Static method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- of(boolean, boolean, boolean, boolean) - Static method in enum org.apache.druid.query.filter.RangeFilter.RangeType
- of(double) - Static method in class org.apache.druid.math.expr.ExprEval
- of(int, int, int, int, int) - Static method in class org.apache.druid.java.util.common.DateTimes
- of(long) - Static method in class org.apache.druid.math.expr.ExprEval
- of(Class<T>) - Static method in class org.apache.druid.guice.ConfigProvider
-
Deprecated.
- of(Class<T>, Map<String, String>) - Static method in class org.apache.druid.guice.ConfigProvider
-
Deprecated.
- of(Integer, Duration) - Static method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- of(Iterable<? extends FrameProcessor<T>>) - Static method in class org.apache.druid.frame.processor.manager.ProcessorManagers
-
Manager with processors derived from an
Iterable
. - of(Object...) - Static method in class org.apache.druid.query.groupby.ResultRow
-
Create a row from an array of objects.
- of(String) - Static method in class org.apache.druid.java.util.common.DateTimes
- of(String) - Static method in class org.apache.druid.java.util.common.Intervals
- of(String) - Static method in class org.apache.druid.math.expr.ExprEval
- of(String) - Static method in class org.apache.druid.query.dimension.DefaultDimensionSpec
- of(String) - Static method in class org.apache.druid.query.filter.InDimFilter.ValuesSet
-
Creates a ValuesSet wrapping the provided single value, with
NullHandling.emptyToNullIfNeeded(String)
applied. - of(String, Class<T>) - Static method in class org.apache.druid.guice.JsonConfigProvider
- of(String, Class<T>, Class<? extends T>) - Static method in class org.apache.druid.guice.JsonConfigProvider
- of(String, Class<T>, T) - Static method in class org.apache.druid.guice.JacksonConfigProvider
- of(String, Object...) - Static method in class org.apache.druid.java.util.common.Intervals
- of(String, Column) - Static method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- of(String, Column, String, Column) - Static method in class org.apache.druid.query.rowsandcols.MapOfColumnsRowsAndColumns
- of(String, ColumnType) - Static method in class org.apache.druid.query.dimension.DefaultDimensionSpec
- of(String, Interval, String, int) - Static method in class org.apache.druid.timeline.SegmentId
- of(String, Interval, String, ShardSpec) - Static method in class org.apache.druid.timeline.SegmentId
- of(ByteOrder, CompressionStrategy) - Static method in class org.apache.druid.segment.data.DecompressingByteBufferObjectStrategy
- of(AtomicReference<T>) - Static method in class org.apache.druid.common.guava.DSuppliers
- of(Supplier<? extends FrameProcessor<T>>) - Static method in class org.apache.druid.frame.processor.manager.ProcessorManagers
-
Manager with a single processor derived from a
Supplier
. - of(List<InputRow>, Map<String, Object>) - Static method in class org.apache.druid.data.input.InputRowListPlusRawValues
- of(Map<String, Object>) - Static method in class org.apache.druid.query.QueryContext
- of(Map<String, Object>, ParseException) - Static method in class org.apache.druid.data.input.InputRowListPlusRawValues
- of(ImmutableBitmap, boolean, long) - Static method in class org.apache.druid.segment.BitmapOffset
- of(InputRow, Map<String, Object>) - Static method in class org.apache.druid.data.input.InputRowListPlusRawValues
- of(Sequence<? extends FrameProcessor<T>>) - Static method in class org.apache.druid.frame.processor.manager.ProcessorManagers
-
Manager with processors derived from a
Sequence
. - of(DimFilter) - Static method in class org.apache.druid.query.filter.IsFalseDimFilter
- of(DimFilter) - Static method in class org.apache.druid.query.filter.IsTrueDimFilter
- of(DimFilter) - Static method in class org.apache.druid.query.filter.NotDimFilter
- of(DruidObjectPredicate<String>) - Static method in class org.apache.druid.query.filter.StringPredicateDruidPredicateFactory
- 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.CursorOnlyStrategy
- of(SearchQuery) - Static method in class org.apache.druid.query.search.UseIndexesStrategy
- of(VectorSizeInspector, ConstantMatcherType) - Static method in class org.apache.druid.query.filter.vector.BooleanVectorValueMatcher
- of(T1, T2) - Static method in class org.apache.druid.java.util.common.Pair
- of(T1, T2, T3) - Static method in class org.apache.druid.java.util.common.Triple
- ofArray(ExpressionType) - Method in class org.apache.druid.math.expr.ExpressionTypeFactory
- ofArray(ExpressionType, Object[]) - Static method in class org.apache.druid.math.expr.ExprEval
- ofArray(ColumnType) - Static method in class org.apache.druid.segment.column.ColumnType
- ofArray(ColumnType) - Method in class org.apache.druid.segment.column.ColumnTypeFactory
- ofArray(Type) - Method in interface org.apache.druid.segment.column.TypeFactory
- ofBoolean(boolean, ExpressionType) - Static method in class org.apache.druid.math.expr.ExprEval
-
Deprecated.
- ofCardinality(int) - Static method in class org.apache.druid.segment.IdMapping.Builder
-
Create a
IdMapping
where the cardinality is known, to use withIdMapping.Builder.addMapping(int)
to simultaneously populate bothIdMapping.Builder.forwardMapping
andIdMapping.Builder.reverseMapping
. - ofCategory(DruidException.Category) - Method in class org.apache.druid.error.DruidException.DruidExceptionBuilder
- ofCategory(DruidException.Category) - Method in class org.apache.druid.error.DruidException.PartialDruidExceptionBuilder
- ofComplex(String) - Method in class org.apache.druid.math.expr.ExpressionTypeFactory
- ofComplex(String) - Static method in class org.apache.druid.segment.column.ColumnType
- ofComplex(String) - Method in class org.apache.druid.segment.column.ColumnTypeFactory
- ofComplex(String) - Method in interface org.apache.druid.segment.column.TypeFactory
- ofComplex(ExpressionType, Object) - Static method in class org.apache.druid.math.expr.ExprEval
- ofCompressedByteBuffers(Iterable<ByteBuffer>, CompressionStrategy, int, ByteOrder, Closer) - Static method in class org.apache.druid.segment.data.GenericIndexed
- ofCompressedByteBuffers(SegmentWriteOutMedium, String, CompressionStrategy, int, Closer) - Static method in class org.apache.druid.segment.data.GenericIndexedWriter
- ofDefault() - Static method in enum org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
- ofDouble() - Method in class org.apache.druid.math.expr.ExpressionTypeFactory
- ofDouble() - Method in class org.apache.druid.segment.column.ColumnTypeFactory
- ofDouble() - Method in interface org.apache.druid.segment.column.TypeFactory
- ofDouble(Number) - Static method in class org.apache.druid.math.expr.ExprEval
- ofDoubleArray(Object[]) - Static method in class org.apache.druid.math.expr.ExprEval
- offer(float) - Method in class org.apache.druid.query.aggregation.Histogram
- offer(MemoryBoundLinkedBlockingQueue.ObjectContainer<T>) - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
- offer(MemoryBoundLinkedBlockingQueue.ObjectContainer<T>, long, TimeUnit) - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
- 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
- ofFloat() - Method in class org.apache.druid.math.expr.ExpressionTypeFactory
- ofFloat() - Method in class org.apache.druid.segment.column.ColumnTypeFactory
- ofFloat() - Method in interface org.apache.druid.segment.column.TypeFactory
- offset - Variable in class org.apache.druid.query.operator.OffsetLimit
- 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
- offset(int) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.Builder
- offset(long) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- Offset - Class in org.apache.druid.segment.data
-
The "mutable" version of a ReadableOffset.
- Offset() - Constructor for class org.apache.druid.segment.data.Offset
- OffsetLimit - Class in org.apache.druid.query.operator
- OffsetLimit(long, long) - Constructor for class org.apache.druid.query.operator.OffsetLimit
- offsetsPosition - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- ofList(List<Map<String, Object>>, List<InputRow>) - Static method in class org.apache.druid.data.input.InputRowListPlusRawValues
-
Create an instance of
InputRowListPlusRawValues
Make sure the size of given rawColumnsList and inputRows are the same if both of them are not null - ofList(List<Map<String, Object>>, List<InputRow>, ParseException) - Static method in class org.apache.druid.data.input.InputRowListPlusRawValues
-
Create an instance of
InputRowListPlusRawValues
Make sure the size of given rawColumnsList and inputRows are the same if both of them are not null - ofList(List<Map<String, Object>>, ParseException) - Static method in class org.apache.druid.data.input.InputRowListPlusRawValues
- ofLong() - Method in class org.apache.druid.math.expr.ExpressionTypeFactory
- ofLong() - Method in class org.apache.druid.segment.column.ColumnTypeFactory
- ofLong() - Method in interface org.apache.druid.segment.column.TypeFactory
- ofLong(Number) - Static method in class org.apache.druid.math.expr.ExprEval
- ofLongArray(Object[]) - Static method in class org.apache.druid.math.expr.ExprEval
- ofLongBoolean(boolean) - Static method in class org.apache.druid.math.expr.ExprEval
-
Convert a boolean into a long expression type
- ofNullable(Boolean) - Static method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- ofString() - Method in class org.apache.druid.math.expr.ExpressionTypeFactory
- ofString() - Method in class org.apache.druid.segment.column.ColumnTypeFactory
- ofString() - Method in interface org.apache.druid.segment.column.TypeFactory
- ofStringArray(Object[]) - Static method in class org.apache.druid.math.expr.ExprEval
- ofType(ExpressionType, Object) - Static method in class org.apache.druid.math.expr.ExprEval
- ofType(TypeSignature<ValueType>) - Static method in class org.apache.druid.segment.column.ColumnTypeFactory
- ofUnknownCardinality() - Static method in class org.apache.druid.segment.IdMapping.Builder
-
Create an
IdMapping
where the cardinality is not known up front. - ofValueType(ValueType) - Static method in class org.apache.druid.segment.column.ColumnTypeFactory
- ok() - Static method in class org.apache.druid.common.config.ConfigManager.SetResult
- ok() - Static method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
- onComplete(T) - Method in class org.apache.druid.frame.processor.manager.ProcessorAndCallback
- ONE_TO_ONE - org.apache.druid.query.extraction.ExtractionFn.ExtractionType
- onesUntil(int) - Static method in class org.apache.druid.extendedset.intset.ConciseSetUtils
- oneUniversalPartition() - Static method in class org.apache.druid.frame.key.ClusterByPartitions
- OnheapIncrementalIndex - Class in org.apache.druid.segment.incremental
- OnheapIncrementalIndex.Builder - Class in org.apache.druid.segment.incremental
- OnheapIncrementalIndex.Spec - 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
- ONLY_COMPLETE - org.apache.druid.timeline.Partitions
-
Specifies that only complete partitions should be considered.
- ONLY_ETERNITY - Static variable in class org.apache.druid.java.util.common.Intervals
- ONLY_EVENTS - org.apache.druid.java.util.emitter.core.BatchingStrategy
- onlyBaseFields(Set<String>, DataSourceAnalysis) - Static method in class org.apache.druid.query.filter.DimFilterUtils
-
Returns a copy of "fields" only including base fields from
DataSourceAnalysis
. - open() - Method in class org.apache.druid.data.input.BytesCountingInputEntity
- open() - Method in class org.apache.druid.data.input.impl.ByteEntity
- open() - Method in class org.apache.druid.data.input.impl.FileEntity
- open() - Method in interface org.apache.druid.data.input.InputEntity
-
Opens an
InputStream
on the input entity directly. - open() - Method in class org.apache.druid.data.input.RetryingInputEntity
-
Open a
RetryingInputStream
wrapper for an underlying input stream, optionally decompressing the retrying stream if the file extension matches a known compression, otherwise passing through the retrying stream directly. - open() - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleColumnSerializer
- open() - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatColumnSerializer
- open() - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongColumnSerializer
- open() - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringColumnSerializer
- 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.CompressedBlockSerializer
- open() - Method in class org.apache.druid.segment.data.CompressedColumnarIntsSerializer
- open() - Method in class org.apache.druid.segment.data.CompressedLongsSerializer
- open() - Method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSerializer
- open() - Method in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSerializer
- open() - Method in interface org.apache.druid.segment.data.DictionaryWriter
- open() - Method in class org.apache.druid.segment.data.EncodedStringDictionaryWriter
- 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.FixedIndexedIntWriter
- open() - Method in class org.apache.druid.segment.data.FixedIndexedWriter
- open() - Method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
- open() - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- 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.nested.FieldTypeInfo.Writer
- open() - Method in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
-
Open the writer so that
GlobalDictionaryEncodedFieldColumnWriter.addValue(int, Object)
can be called - open() - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- open() - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- open() - Method in class org.apache.druid.segment.nested.ScalarDoubleFieldColumnWriter
- open() - Method in class org.apache.druid.segment.nested.ScalarLongFieldColumnWriter
- open() - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- open() - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- open() - Method in class org.apache.druid.segment.serde.ComplexColumnSerializer
- open() - Method in class org.apache.druid.segment.serde.LargeColumnSupportedComplexColumnSerializer
- open(File, ByteTracker, FrameFile.Flag...) - Static method in class org.apache.druid.frame.file.FrameFile
-
Open a frame file with certain optional flags.
- open(InputStream, String, ExecutorService, boolean) - Static method in class org.apache.druid.frame.channel.ReadableInputStreamFrameChannel
-
Create an instance of this class and immediately start reading from the provided InputStream.
- open(WritableByteChannel, ByteBuffer, ByteTracker) - Static method in class org.apache.druid.frame.file.FrameFileWriter
-
Opens a writer for a particular channel.
- open(Iterator<ReadableFrameChannel>) - Static method in class org.apache.druid.frame.channel.ReadableConcatFrameChannel
-
Creates a new concatenated channel.
- open(T) - Method in interface org.apache.druid.data.input.impl.prefetch.ObjectOpenFunction
- open(T, long) - Method in interface org.apache.druid.data.input.impl.prefetch.ObjectOpenFunction
- OPEN - org.apache.druid.query.filter.RangeFilter.RangeType
-
(...)
- openChannel(int) - Method in class org.apache.druid.frame.processor.BlockingQueueOutputChannelFactory
- openChannel(int) - Method in class org.apache.druid.frame.processor.ComposingOutputChannelFactory
- openChannel(int) - Method in class org.apache.druid.frame.processor.FileOutputChannelFactory
- openChannel(int) - Method in interface org.apache.druid.frame.processor.OutputChannelFactory
-
Create a channel pair tagged with a particular partition number.
- openDictionaryWriter() - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- openDictionaryWriter() - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- openDictionaryWriter() - Method in class org.apache.druid.segment.nested.ScalarDoubleColumnSerializer
- openDictionaryWriter() - Method in class org.apache.druid.segment.nested.ScalarLongColumnSerializer
- openDictionaryWriter() - Method in class org.apache.druid.segment.nested.ScalarStringColumnSerializer
- openDictionaryWriter() - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- openInputStream(URI, String, PasswordProvider, long) - Static method in class org.apache.druid.data.input.impl.HttpEntity
- openNilChannel(int) - Method in class org.apache.druid.frame.processor.BlockingQueueOutputChannelFactory
- openNilChannel(int) - Method in class org.apache.druid.frame.processor.ComposingOutputChannelFactory
- openNilChannel(int) - Method in class org.apache.druid.frame.processor.FileOutputChannelFactory
- openNilChannel(int) - Method in interface org.apache.druid.frame.processor.OutputChannelFactory
-
Create a non-writable, always-empty channel pair tagged with a particular partition number.
- openPartitionedChannel(String, boolean) - Method in class org.apache.druid.frame.processor.BlockingQueueOutputChannelFactory
- openPartitionedChannel(String, boolean) - Method in class org.apache.druid.frame.processor.ComposingOutputChannelFactory
- openPartitionedChannel(String, boolean) - Method in class org.apache.druid.frame.processor.FileOutputChannelFactory
- openPartitionedChannel(String, boolean) - Method in interface org.apache.druid.frame.processor.OutputChannelFactory
-
Create a channel pair tagged with a particular name and a flag to delete the channel data after its read.
- openStream() - Method in interface org.apache.druid.java.util.common.FileUtils.InputStreamSupplier
- openValueColumnSerializer() - Method in class org.apache.druid.segment.nested.ScalarDoubleColumnSerializer
- openValueColumnSerializer() - Method in class org.apache.druid.segment.nested.ScalarLongColumnSerializer
- openValueColumnSerializer() - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
-
Called during
ScalarNestedCommonFormatColumnSerializer.open()
to allow opening any separate type specific value column serializers - openValueColumnSerializer() - Method in class org.apache.druid.segment.nested.ScalarStringColumnSerializer
- operator(ExpressionType, ExpressionType) - Static method in class org.apache.druid.math.expr.ExpressionTypeConversion
-
Given 2 'input' types, choose the most appropriate combined type, if possible arrays must be the same type if both types are
ExprType.STRING
, the output type will be preserved as string if both types areExprType.LONG
, the output type will be preserved as long otherwise, output isExprType.DOUBLE
- Operator - Interface in org.apache.druid.query.operator
-
An Operator interface that intends to have implementations that align relatively closely with the Operators that other databases would also tend to be implemented using.
- OPERATOR - org.apache.druid.error.DruidException.Persona
-
Represents a persona who actively owns and operates the cluster.
- Operator.Receiver - Interface in org.apache.druid.query.operator
- Operator.Signal - Enum in org.apache.druid.query.operator
-
This is the return object from a receiver.
- OperatorFactory - Interface in org.apache.druid.query.operator
-
A factory for Operators.
- OperatorSequence - Class in org.apache.druid.query.operator
-
Provides a sequence on top of Operators.
- OperatorSequence(Supplier<Operator>) - Constructor for class org.apache.druid.query.operator.OperatorSequence
- optimize(boolean) - Method in class org.apache.druid.query.filter.AbstractOptimizableDimFilter
- optimize(boolean) - Method in class org.apache.druid.query.filter.AndDimFilter
- optimize(boolean) - Method in interface org.apache.druid.query.filter.DimFilter
-
Returns an optimized version of this filter.
- optimize(boolean) - Method in class org.apache.druid.query.filter.ExtractionDimFilter
-
Deprecated.
- optimize(boolean) - Method in class org.apache.druid.query.filter.InDimFilter
- optimize(boolean) - Method in class org.apache.druid.query.filter.IsFalseDimFilter
- optimize(boolean) - Method in class org.apache.druid.query.filter.IsTrueDimFilter
- optimize(boolean) - Method in class org.apache.druid.query.filter.NotDimFilter
- optimize(boolean) - Method in class org.apache.druid.query.filter.OrDimFilter
- optimize(boolean) - Method in class org.apache.druid.query.filter.SelectorDimFilter
- optimize(boolean) - Method in class org.apache.druid.query.filter.TypedInFilter
- optimize(List<DimFilter>, boolean) - Static method in class org.apache.druid.query.filter.DimFilters
- 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
- optimizeLookup(InDimFilter, boolean) - Static method in class org.apache.druid.query.filter.InDimFilter
-
If the provided "in" filter uses a
LookupExtractionFn
that can be reversed, then return the matching set of keys as aInDimFilter.ValuesSet
. - optimizeLookup(InDimFilter, boolean, int) - Static method in class org.apache.druid.query.filter.InDimFilter
-
If the provided "in" filter uses a
LookupExtractionFn
that can be reversed, then return the matching set of keys as aInDimFilter.ValuesSet
. - optionBinder(Binder, Key<T>) - Static method in class org.apache.druid.guice.PolyBind
-
Binds an option for a specific choice.
- or(List<DimFilter>) - Static method in class org.apache.druid.query.filter.DimFilters
- or(List<Filter>) - Static method in class org.apache.druid.segment.filter.Filters
-
Create a filter representing an OR relationship across a list of filters.
- 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(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Creates an
ExprVectorProcessor
for the logical 'or' operator, which produces a long typed vector output with values set by the following rules: true/null, null/true -> true (1) false/null, null/false, null/null -> null false/false -> false (0) - or(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 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- OR - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- order() - Method in class org.apache.druid.frame.key.KeyColumn
- 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(List<ScanQuery.OrderBy>) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- orderBy(OrderByColumnSpec...) - Method in class org.apache.druid.query.groupby.orderby.DefaultLimitSpec.Builder
- OrderBy(String, ScanQuery.Order) - Constructor for class org.apache.druid.query.scan.ScanQuery.OrderBy
- OrderByColumnSpec - Class in org.apache.druid.query.groupby.orderby
- OrderByColumnSpec(String, OrderByColumnSpec.Direction) - Constructor for class org.apache.druid.query.groupby.orderby.OrderByColumnSpec
- OrderByColumnSpec(String, OrderByColumnSpec.Direction, StringComparator) - 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(String, String, String...) - Constructor for class org.apache.druid.query.filter.OrDimFilter
- OrDimFilter(List<DimFilter>) - Constructor for class org.apache.druid.query.filter.OrDimFilter
- OrDimFilter(DimFilter...) - Constructor for class org.apache.druid.query.filter.OrDimFilter
- OrFilter - Class in org.apache.druid.segment.filter
-
Logical OR filter operation
- OrFilter(LinkedHashSet<Filter>) - Constructor for class org.apache.druid.segment.filter.OrFilter
- OrFilter(List<Filter>) - Constructor for class org.apache.druid.segment.filter.OrFilter
- org.apache.druid.annotations - package org.apache.druid.annotations
- org.apache.druid.audit - package org.apache.druid.audit
- org.apache.druid.cli - package org.apache.druid.cli
- org.apache.druid.collections - package org.apache.druid.collections
- org.apache.druid.collections.bitmap - package org.apache.druid.collections.bitmap
- org.apache.druid.collections.fastutil - package org.apache.druid.collections.fastutil
- 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.common.config - package org.apache.druid.common.config
- org.apache.druid.common.exception - package org.apache.druid.common.exception
- org.apache.druid.common.guava - package org.apache.druid.common.guava
- org.apache.druid.common.utils - package org.apache.druid.common.utils
- org.apache.druid.concurrent - package org.apache.druid.concurrent
- org.apache.druid.crypto - package org.apache.druid.crypto
- org.apache.druid.data - package org.apache.druid.data
- org.apache.druid.data.input - package org.apache.druid.data.input
- org.apache.druid.data.input.impl - package org.apache.druid.data.input.impl
- org.apache.druid.data.input.impl.prefetch - package org.apache.druid.data.input.impl.prefetch
- org.apache.druid.data.input.impl.systemfield - package org.apache.druid.data.input.impl.systemfield
- org.apache.druid.error - package org.apache.druid.error
- org.apache.druid.extendedset.intset - package org.apache.druid.extendedset.intset
- org.apache.druid.extendedset.utilities - package org.apache.druid.extendedset.utilities
- org.apache.druid.frame - package org.apache.druid.frame
- org.apache.druid.frame.allocation - package org.apache.druid.frame.allocation
- org.apache.druid.frame.channel - package org.apache.druid.frame.channel
- org.apache.druid.frame.field - package org.apache.druid.frame.field
- org.apache.druid.frame.file - package org.apache.druid.frame.file
- org.apache.druid.frame.key - package org.apache.druid.frame.key
- org.apache.druid.frame.processor - package org.apache.druid.frame.processor
- org.apache.druid.frame.processor.manager - package org.apache.druid.frame.processor.manager
- org.apache.druid.frame.read - package org.apache.druid.frame.read
- org.apache.druid.frame.read.columnar - package org.apache.druid.frame.read.columnar
- org.apache.druid.frame.segment - package org.apache.druid.frame.segment
- org.apache.druid.frame.segment.columnar - package org.apache.druid.frame.segment.columnar
- org.apache.druid.frame.segment.row - package org.apache.druid.frame.segment.row
- org.apache.druid.frame.util - package org.apache.druid.frame.util
- org.apache.druid.frame.write - package org.apache.druid.frame.write
- org.apache.druid.frame.write.columnar - package org.apache.druid.frame.write.columnar
- org.apache.druid.guice - package org.apache.druid.guice
- org.apache.druid.guice.annotations - package org.apache.druid.guice.annotations
- org.apache.druid.hll - package org.apache.druid.hll
- org.apache.druid.indexer - package org.apache.druid.indexer
- org.apache.druid.indexer.partitions - package org.apache.druid.indexer.partitions
- org.apache.druid.indexer.report - package org.apache.druid.indexer.report
- org.apache.druid.initialization - package org.apache.druid.initialization
- org.apache.druid.io - package org.apache.druid.io
- org.apache.druid.jackson - package org.apache.druid.jackson
- org.apache.druid.java.util - package org.apache.druid.java.util
- org.apache.druid.java.util.common - package org.apache.druid.java.util.common
- org.apache.druid.java.util.common.collect - package org.apache.druid.java.util.common.collect
- org.apache.druid.java.util.common.concurrent - package org.apache.druid.java.util.common.concurrent
- org.apache.druid.java.util.common.config - package org.apache.druid.java.util.common.config
- org.apache.druid.java.util.common.function - package org.apache.druid.java.util.common.function
- org.apache.druid.java.util.common.granularity - package org.apache.druid.java.util.common.granularity
- org.apache.druid.java.util.common.guava - package org.apache.druid.java.util.common.guava
- org.apache.druid.java.util.common.guava.nary - package org.apache.druid.java.util.common.guava.nary
- org.apache.druid.java.util.common.io - package org.apache.druid.java.util.common.io
- org.apache.druid.java.util.common.io.smoosh - package org.apache.druid.java.util.common.io.smoosh
- org.apache.druid.java.util.common.jackson - package org.apache.druid.java.util.common.jackson
- org.apache.druid.java.util.common.lifecycle - package org.apache.druid.java.util.common.lifecycle
- org.apache.druid.java.util.common.logger - package org.apache.druid.java.util.common.logger
- org.apache.druid.java.util.common.parsers - package org.apache.druid.java.util.common.parsers
- org.apache.druid.java.util.emitter - package org.apache.druid.java.util.emitter
- org.apache.druid.java.util.emitter.core - package org.apache.druid.java.util.emitter.core
- org.apache.druid.java.util.emitter.factory - package org.apache.druid.java.util.emitter.factory
- org.apache.druid.java.util.emitter.service - package org.apache.druid.java.util.emitter.service
- org.apache.druid.java.util.http.client - package org.apache.druid.java.util.http.client
- org.apache.druid.java.util.http.client.auth - package org.apache.druid.java.util.http.client.auth
- org.apache.druid.java.util.http.client.io - package org.apache.druid.java.util.http.client.io
- org.apache.druid.java.util.http.client.netty - package org.apache.druid.java.util.http.client.netty
- org.apache.druid.java.util.http.client.pool - package org.apache.druid.java.util.http.client.pool
- org.apache.druid.java.util.http.client.response - package org.apache.druid.java.util.http.client.response
- org.apache.druid.java.util.metrics - package org.apache.druid.java.util.metrics
- org.apache.druid.java.util.metrics.cgroups - package org.apache.druid.java.util.metrics.cgroups
- org.apache.druid.js - package org.apache.druid.js
- org.apache.druid.math.expr - package org.apache.druid.math.expr
- org.apache.druid.math.expr.antlr - package org.apache.druid.math.expr.antlr
- org.apache.druid.math.expr.vector - package org.apache.druid.math.expr.vector
- org.apache.druid.metadata - package org.apache.druid.metadata
- 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.cardinality.vector - package org.apache.druid.query.aggregation.cardinality.vector
- org.apache.druid.query.aggregation.constant - package org.apache.druid.query.aggregation.constant
- org.apache.druid.query.aggregation.firstlast - package org.apache.druid.query.aggregation.firstlast
- org.apache.druid.query.aggregation.firstlast.first - package org.apache.druid.query.aggregation.firstlast.first
- org.apache.druid.query.aggregation.firstlast.last - package org.apache.druid.query.aggregation.firstlast.last
- org.apache.druid.query.aggregation.hyperloglog - package org.apache.druid.query.aggregation.hyperloglog
- 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.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.operator - package org.apache.druid.query.operator
- org.apache.druid.query.operator.join - package org.apache.druid.query.operator.join
- org.apache.druid.query.operator.window - package org.apache.druid.query.operator.window
- org.apache.druid.query.operator.window.ranking - package org.apache.druid.query.operator.window.ranking
- org.apache.druid.query.operator.window.value - package org.apache.druid.query.operator.window.value
- 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.rowsandcols - package org.apache.druid.query.rowsandcols
- org.apache.druid.query.rowsandcols.column - package org.apache.druid.query.rowsandcols.column
- org.apache.druid.query.rowsandcols.column.accessor - package org.apache.druid.query.rowsandcols.column.accessor
- org.apache.druid.query.rowsandcols.concrete - package org.apache.druid.query.rowsandcols.concrete
- org.apache.druid.query.rowsandcols.semantic - package org.apache.druid.query.rowsandcols.semantic
- org.apache.druid.query.rowsandcols.util - package org.apache.druid.query.rowsandcols.util
- 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.index - package org.apache.druid.segment.index
- org.apache.druid.segment.index.semantic - package org.apache.druid.segment.index.semantic
- 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.nested - package org.apache.druid.segment.nested
- 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.serde.cell - package org.apache.druid.segment.serde.cell
- 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
- org.apache.druid.storage - package org.apache.druid.storage
- org.apache.druid.storage.local - package org.apache.druid.storage.local
- org.apache.druid.storage.remote - package org.apache.druid.storage.remote
- org.apache.druid.tasklogs - package org.apache.druid.tasklogs
- org.apache.druid.timeline - package org.apache.druid.timeline
- org.apache.druid.timeline.partition - package org.apache.druid.timeline.partition
- org.apache.druid.utils - package org.apache.druid.utils
- 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
- OshiSysMonitor - Class in org.apache.druid.java.util.metrics
-
SysMonitor implemented using
oshi
- OshiSysMonitor() - Constructor for class org.apache.druid.java.util.metrics.OshiSysMonitor
- OshiSysMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.OshiSysMonitor
- OshiSysMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.OshiSysMonitor
- OshiSysMonitor(SystemInfo) - Constructor for class org.apache.druid.java.util.metrics.OshiSysMonitor
- OutputChannel - Class in org.apache.druid.frame.processor
-
Represents an output channel for some frame processor.
- OutputChannelFactory - Interface in org.apache.druid.frame.processor
-
Factory for generating channel pairs for output data from processors.
- outputChannels() - Method in class org.apache.druid.frame.processor.FrameChannelBatcher
- outputChannels() - Method in class org.apache.druid.frame.processor.FrameChannelHashPartitioner
- outputChannels() - Method in class org.apache.druid.frame.processor.FrameChannelMerger
- outputChannels() - Method in class org.apache.druid.frame.processor.FrameChannelMixer
- outputChannels() - Method in interface org.apache.druid.frame.processor.FrameProcessor
-
List of output channels.
- OutputChannels - Class in org.apache.druid.frame.processor
-
A list of
OutputChannel
. - outsideBounds(int) - Method in class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- overflowsUnsignedInt(long) - Static method in class org.apache.druid.query.expression.IPv4AddressExprUtils
- 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<float[]>) - Method in class org.apache.druid.collections.spatial.search.RectangularBound
- overlaps(ImmutableNode<TCoordinateArray>) - Method in interface org.apache.druid.collections.spatial.search.Bound
- override(Map<String, Object>, String, Object) - Static method in class org.apache.druid.query.QueryContexts
-
Insert, update or remove a single key to produce an overridden context.
- override(Map<String, Object>, Map<String, Object>) - Static method in class org.apache.druid.query.QueryContexts
-
Insert or replace multiple keys to produce an overridden context.
- overrideContext(Map<String, Object>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- Overshadowable<T extends Overshadowable<T>> - Interface in org.apache.druid.timeline
-
Interface to represent a class which can have overshadow relation between its instances.
- overshadows(ReferenceCountingSegment) - Method in class org.apache.druid.segment.ReferenceCountingSegment
- overshadows(DataSegment) - Method in class org.apache.druid.timeline.DataSegment
- overshadows(T) - Method in interface org.apache.druid.timeline.Overshadowable
-
Returns true if this overshadowable overshadows the other.
- OverwriteShardSpec - Interface in org.apache.druid.timeline.partition
-
ShardSpec for non-first-generation segments.
- ownerThread - Variable in class org.apache.druid.query.DefaultQueryMetrics
-
Non final to give subclasses ability to reassign it.
P
- pair(WritableFrameChannel, MemoryAllocator, Supplier<PartitionedReadableFrameChannel>) - Static method in class org.apache.druid.frame.processor.PartitionedOutputChannel
-
Creates a partitioned output channel pair.
- pair(WritableFrameChannel, MemoryAllocator, Supplier<ReadableFrameChannel>, int) - Static method in class org.apache.druid.frame.processor.OutputChannel
-
Creates an output channel pair, where the readable channel is not usable until writing is complete.
- Pair<T1,T2> - Class in org.apache.druid.java.util.common
- Pair(T1, T2) - Constructor for class org.apache.druid.java.util.common.Pair
- 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
- ParallelMergeCombiningSequence<T> - Class in org.apache.druid.java.util.common.guava
-
Artisanal, locally-sourced, hand-crafted, gluten and GMO free, bespoke, free-range, organic, small-batch parallel merge combining sequence.
- ParallelMergeCombiningSequence(ForkJoinPool, List<Sequence<T>>, Ordering<T>, BinaryOperator<T>, boolean, long, int, int, int, int, int, Consumer<ParallelMergeCombiningSequence.MergeCombineMetrics>) - Constructor for class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence
- ParallelMergeCombiningSequence.MergeCombineMetrics - Class in org.apache.druid.java.util.common.guava
-
Metrics for the execution of a
ParallelMergeCombiningSequence
on theForkJoinPool
- 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
- ParametrizedUriEmitter - Class in org.apache.druid.java.util.emitter.core
- ParametrizedUriEmitter(ParametrizedUriEmitterConfig, AsyncHttpClient, ObjectMapper) - Constructor for class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitter
- ParametrizedUriEmitter(ParametrizedUriEmitterConfig, AsyncHttpClient, ObjectMapper, UriExtractor) - Constructor for class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitter
- ParametrizedUriEmitterConfig - Class in org.apache.druid.java.util.emitter.core
- ParametrizedUriEmitterConfig() - Constructor for class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitterConfig
- ParametrizedUriEmitterFactory - Class in org.apache.druid.java.util.emitter.factory
- ParametrizedUriEmitterFactory() - Constructor for class org.apache.druid.java.util.emitter.factory.ParametrizedUriEmitterFactory
- ParametrizedUriEmitterMonitor - Class in org.apache.druid.java.util.metrics
- ParametrizedUriEmitterMonitor(String, ParametrizedUriEmitter) - Constructor for class org.apache.druid.java.util.metrics.ParametrizedUriEmitterMonitor
- ParametrizedUriExtractor - Class in org.apache.druid.java.util.emitter.core
- ParametrizedUriExtractor(String) - Constructor for class org.apache.druid.java.util.emitter.core.ParametrizedUriExtractor
- Parent - Annotation Type in org.apache.druid.guice.annotations
-
Binding annotation for org.apache.druid.server.DruidNode.
- parse(byte[]) - Static method in class org.apache.druid.query.expression.IPv6AddressExprUtils
- parse(long) - Static method in class org.apache.druid.query.expression.IPv4AddressExprUtils
- parse(InputStream, String) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- parse(String) - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- parse(String) - Method in class org.apache.druid.java.util.common.DateTimes.UtcFormatter
- parse(String) - Static method in class org.apache.druid.java.util.common.HumanReadableBytes
- parse(String) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- parse(String) - Static method in class org.apache.druid.query.expression.IPv4AddressExprUtils
- parse(String) - Static method in class org.apache.druid.query.expression.IPv6AddressExprUtils
- parse(String) - Method in class org.apache.druid.segment.transform.TransformingStringInputRowParser
- parse(String, long) - Static method in class org.apache.druid.java.util.common.HumanReadableBytes
-
parse the case-insensitive string number, which is either:
- parse(String, String) - Static method in class org.apache.druid.java.util.common.URIs
- parse(String, ExprMacroTable) - Static method in class org.apache.druid.math.expr.Parser
-
Parse a string into a flattened
Expr
. - parse(String, ExprMacroTable, boolean) - Static method in class org.apache.druid.math.expr.Parser
- parse(TimestampSpec, List<String>, Map<String, Object>) - Static method in class org.apache.druid.data.input.impl.MapInputRowParser
- parse(InputRowSchema, Map<String, Object>) - Static method in class org.apache.druid.data.input.impl.MapInputRowParser
- parse(RowSignature, TimestampSpec, List<String>, List<Object>) - Static method in class org.apache.druid.data.input.ListBasedInputRow
-
Create a row and parse a timestamp.
- parse(T) - Method in interface org.apache.druid.data.input.impl.InputRowParser
-
Deprecated.
- parseBatch(ByteBuffer) - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- parseBatch(ByteBuffer) - Method in class org.apache.druid.segment.transform.TransformingStringInputRowParser
- parseBatch(Map<String, Object>) - Method in class org.apache.druid.data.input.impl.MapInputRowParser
- parseBatch(InputRow) - Method in class org.apache.druid.data.input.impl.NoopInputRowParser
- parseBatch(T) - Method in interface org.apache.druid.data.input.impl.InputRowParser
-
Deprecated.Parse an input into list of
InputRow
. - parseBatch(T) - Method in class org.apache.druid.segment.transform.TransformingInputRowParser
- parseBoolean(Object) - Static method in class org.apache.druid.java.util.common.Numbers
-
Parse the given object as a
boolean
. - parseBoolean(Map<String, Object>, String, boolean) - Static method in class org.apache.druid.query.QueryContexts
- parseDateTime(Object) - Method in class org.apache.druid.data.input.impl.TimestampSpec
- parseDoubleObject(String) - Static method in class org.apache.druid.java.util.common.Numbers
-
Like
Numbers.tryParseDouble(java.lang.Object, double)
, but does not produce a primitive and will explode if unable to produce a Double similar toDouble.parseDouble(java.lang.String)
- ParseException - Exception in org.apache.druid.java.util.common.parsers
-
ParseException can be thrown on both ingestion side and query side.
- ParseException(String, boolean, String, Object...) - Constructor for exception org.apache.druid.java.util.common.parsers.ParseException
- ParseException(String, boolean, Throwable, String, Object...) - Constructor for exception org.apache.druid.java.util.common.parsers.ParseException
- ParseException(String, String, Object...) - Constructor for exception org.apache.druid.java.util.common.parsers.ParseException
- ParseException(String, Throwable, String, Object...) - Constructor for exception org.apache.druid.java.util.common.parsers.ParseException
- ParseExceptionHandler - Class in org.apache.druid.segment.incremental
-
A handler for
ParseException
s thrown during ingestion. - ParseExceptionHandler(RowIngestionMeters, boolean, int, int) - Constructor for class org.apache.druid.segment.incremental.ParseExceptionHandler
- ParseExceptionReport - Class in org.apache.druid.segment.incremental
- ParseExceptionReport(String, String, List<String>, long) - Constructor for class org.apache.druid.segment.incremental.ParseExceptionReport
- parseFloat(Map<String, Object>, String, float) - Static method in class org.apache.druid.query.QueryContexts
- parseInputRows(byte[]) - Method in class org.apache.druid.data.input.impl.DelimitedValueReader
- parseInputRows(byte[]) - Method in class org.apache.druid.data.input.impl.JsonLineReader
- parseInputRows(JsonNode) - Method in class org.apache.druid.data.input.impl.JsonNodeReader
- parseInputRows(String) - Method in class org.apache.druid.data.input.impl.RegexReader
- parseInputRows(InputEntity) - Method in class org.apache.druid.data.input.impl.JsonReader
- parseInputRows(T) - Method in class org.apache.druid.data.input.IntermediateRowParsingReader
-
Parses the given intermediate row into a list of
InputRow
s. - parseInputRows(T) - Method in class org.apache.druid.data.input.TextReader
-
Parses the given line into a list of
InputRow
s. - parseInt(Object) - Static method in class org.apache.druid.java.util.common.Numbers
-
Parse the given object as a
int
. - parseInt(Map<String, Object>, String, int) - Static method in class org.apache.druid.query.QueryContexts
- parseJqPath(String) - Static method in class org.apache.druid.segment.nested.NestedPathFinder
-
split a jq path into a series of extractors to find things in stuff
- ParseJsonExprMacro(ObjectMapper) - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.ParseJsonExprMacro
- parseJsonPath(String) - Static method in class org.apache.druid.segment.nested.NestedPathFinder
-
split a JSONPath path into a series of extractors to find things in stuff
- parseLine(String) - Method in class org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser
- parseLine(String) - Method in class org.apache.druid.java.util.common.parsers.CSVParser
- parseLine(String) - Method in class org.apache.druid.java.util.common.parsers.DelimitedParser
- parseLong(Object) - Static method in class org.apache.druid.java.util.common.Numbers
-
Parse the given object as a
long
. - parseLong(Map<String, Object>, String, long) - Static method in class org.apache.druid.query.QueryContexts
- parseLong(Expr.VectorInputBindingInspector, Expr, int) - Static method in class org.apache.druid.math.expr.vector.VectorProcessors
-
Creates an
ExprVectorProcessor
that will parse a string into a long value given a radix. - ParseLong() - Constructor for class org.apache.druid.math.expr.Function.ParseLong
- parseLongObject(String) - Static method in class org.apache.druid.java.util.common.Numbers
-
Like
Numbers.tryParseLong(java.lang.Object, long)
but does not produce a primitive and will explode if unable to produce a Long similar toLong.parseLong(java.lang.String, int)
- parsePath(String) - Method in class org.apache.druid.segment.nested.CompressedNestedDataComplexColumn
- parsePath(String) - Method in class org.apache.druid.segment.nested.NestedDataColumnV3
- parsePath(String) - Method in class org.apache.druid.segment.nested.NestedDataColumnV4
- parsePath(String) - Method in class org.apache.druid.segment.nested.NestedDataColumnV5
- Parser - Class in org.apache.druid.math.expr
- Parser<K,V> - Interface in org.apache.druid.java.util.common.parsers
-
Class that can parse Strings into Maps.
- Parser() - Constructor for class org.apache.druid.math.expr.Parser
- Parsers - Class in org.apache.druid.java.util.common.parsers
- Parsers() - Constructor for class org.apache.druid.java.util.common.parsers.Parsers
- ParserUtils - Class in org.apache.druid.java.util.common.parsers
- ParserUtils() - Constructor for class org.apache.druid.java.util.common.parsers.ParserUtils
- ParseSpec - Class in org.apache.druid.data.input.impl
-
Deprecated.
- ParseSpec(TimestampSpec, DimensionsSpec) - Constructor for class org.apache.druid.data.input.impl.ParseSpec
-
Deprecated.
- parseString(String) - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- parseString(String) - Static method in class org.apache.druid.query.expression.IPv4AddressExprUtils
- parseString(String) - Static method in class org.apache.druid.query.expression.IPv6AddressExprUtils
- parseString(Map<String, Object>, String) - Static method in class org.apache.druid.query.QueryContexts
- parseString(Map<String, Object>, String, String) - Static method in class org.apache.druid.query.QueryContexts
- parseTimestamp(TimestampSpec, Map<String, Object>) - Static method in class org.apache.druid.data.input.impl.MapInputRowParser
- parseTimestampOrThrowParseException(Object, TimestampSpec, Supplier<Map<String, ?>>) - Static method in class org.apache.druid.data.input.impl.MapInputRowParser
-
Given a plain Java Object, extract a timestamp from it using the provided
TimestampSpec
, or throw aParseException
if we can't. - parseToMap(String) - Method in class org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser
- parseToMap(String) - Method in class org.apache.druid.java.util.common.parsers.JavaScriptParser
- parseToMap(String) - Method in class org.apache.druid.java.util.common.parsers.JSONPathParser
- parseToMap(String) - Method in class org.apache.druid.java.util.common.parsers.JSONToLowerParser
-
Deprecated.
- parseToMap(String) - Method in interface org.apache.druid.java.util.common.parsers.Parser
-
Parse a String into a Map.
- parseToMap(String) - Method in class org.apache.druid.java.util.common.parsers.RegexParser
- partial(int, String) - Static method in class org.apache.druid.query.groupby.epinephelinae.AggregateResult
- PartialShardSpec - Interface in org.apache.druid.timeline.partition
-
This interface is used in the segment allocation protocol when it is coordinated by the Overlord; when appending segments to an existing datasource (either streaming ingestion or batch append) or any case when segment lock is used.
- partition() - Method in class org.apache.druid.frame.channel.FrameWithPartition
- PARTITION - Static variable in class org.apache.druid.query.DruidMetrics
- PARTITION_DIMENSIONS - Static variable in interface org.apache.druid.indexer.partitions.DimensionBasedPartitionsSpec
- PartitionBoundaries - Class in org.apache.druid.timeline.partition
-
List of range partition boundaries.
- PartitionBoundaries(StringTuple...) - Constructor for class org.apache.druid.timeline.partition.PartitionBoundaries
- PartitionChunk<T> - Interface in org.apache.druid.timeline.partition
-
A PartitionChunk represents a chunk of a partitioned(sharded) space.
- PartitionChunkEntry(Interval, VersionType, PartitionChunk<ObjectType>) - Constructor for class org.apache.druid.timeline.VersionedIntervalTimeline.PartitionChunkEntry
- PartitionedOutputChannel - Class in org.apache.druid.frame.processor
-
A channel which can contain multiple partitions of data.
- PartitionedReadableFrameChannel - Interface in org.apache.druid.frame.channel
-
Provides an interface to read a partitioned frame channel.
- PartitionHolder<T extends Overshadowable<T>> - Class in org.apache.druid.timeline.partition
-
An object that clumps together multiple other objects which each represent a shard of some space.
- PartitionHolder(List<PartitionChunk<T>>) - Constructor for class org.apache.druid.timeline.partition.PartitionHolder
- PartitionHolder(OvershadowableManager<T>, short) - Constructor for class org.apache.druid.timeline.partition.PartitionHolder
- PartitionHolder(PartitionChunk<T>) - Constructor for class org.apache.druid.timeline.partition.PartitionHolder
- PartitionIds - Class in org.apache.druid.timeline.partition
- PARTITIONING_TYPE - Static variable in class org.apache.druid.query.DruidMetrics
- partitionOnBoundaries(List<String>) - Method in interface org.apache.druid.query.rowsandcols.semantic.ClusteredGroupPartitioner
-
Semantically equivalent to computeBoundaries, but returns a list of RowsAndColumns objects instead of just boundary positions.
- partitionOnBoundaries(List<String>) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultClusteredGroupPartitioner
- Partitions - Enum in org.apache.druid.timeline
-
This enum is used a parameter for several methods in
VersionedIntervalTimeline
, specifying whether only complete partitions should be considered, or incomplete partitions as well. - PartitionsSpec - Interface in org.apache.druid.indexer.partitions
-
PartitionsSpec describes the secondary partitioning method for data ingestion.
- parts - Variable in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- PasswordProvider - Interface in org.apache.druid.metadata
-
Deprecated.
- PasswordProviderRedactionMixIn - Interface in org.apache.druid.metadata
-
This Interface is used as a MixIn for ObjectMapper objects when there is a desire to avoid serializing a Password from a PasswordProvider to JSON in plaintext when that JSON is going to be used for purposes that don't require the password to be present, such as logging to a file.
- PATH - org.apache.druid.data.input.impl.systemfield.SystemField
- PATH - org.apache.druid.java.util.common.parsers.JSONPathFieldType
- pathExists(String) - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
- pathExists(String) - Method in class org.apache.druid.storage.NilStorageConnector
- pathExists(String) - Method in interface org.apache.druid.storage.StorageConnector
-
Check if the path exists in the underlying storage layer.
- PAUSE - org.apache.druid.query.operator.Operator.Signal
-
Inidcates that the downstream processing should pause its pushing of results and instead return a continuation object that encapsulates whatever state is required to resume processing.
- payload() - Method in annotation type org.apache.druid.java.util.common.HumanReadableBytesRange
- payload(Object) - Method in class org.apache.druid.audit.AuditEntry.Builder
- PayloadEntrySpan - Class in org.apache.druid.segment.serde.cell
- PayloadEntrySpan(long, int) - Constructor for class org.apache.druid.segment.serde.cell.PayloadEntrySpan
- payloads() - Method in class org.apache.druid.timeline.partition.PartitionHolder
- 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
- PENDING - org.apache.druid.indexer.RunnerTaskState
- perform() - Method in interface org.apache.druid.java.util.common.RetryUtils.Task
-
This method is tried up to maxTries times unless it succeeds.
- PeriodGranularity - Class in org.apache.druid.java.util.common.granularity
-
PeriodGranularity buckets data based on any custom time period
- PeriodGranularity(Period, DateTime, DateTimeZone) - Constructor for class org.apache.druid.java.util.common.granularity.PeriodGranularity
- 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
-
Equivalent to
IndexMerger.persist(IncrementalIndex, Interval, File, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory)
without a progress indicator and with interval set toIncrementalIndex.getInterval()
. - persist(IncrementalIndex, Interval, File, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory) - Method in interface org.apache.druid.segment.IndexMerger
-
Persist an IncrementalIndex to disk in such a way that it can be loaded back up as a
QueryableIndex
. - persist(IncrementalIndex, Interval, File, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory) - Method in class org.apache.druid.segment.IndexMergerV9
- persist(IncrementalIndex, Interval, File, IndexSpec, SegmentWriteOutMediumFactory) - Method in interface org.apache.druid.segment.IndexMerger
-
Equivalent to
IndexMerger.persist(IncrementalIndex, Interval, File, IndexSpec, ProgressIndicator, SegmentWriteOutMediumFactory)
without a progress indicator. - persistAndIncrement(int) - Method in class org.apache.druid.segment.serde.cell.CellIndexWriter
- persistAndIncrement(int) - Method in class org.apache.druid.segment.serde.cell.IndexWriter
- persistIterable() - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
-
Get all
IncrementalIndexRow
to persist, ordered withComparator
- physicalRow(int) - Method in class org.apache.druid.frame.Frame
-
Maps a logical row number to a physical row number.
- Pi() - Constructor for class org.apache.druid.math.expr.Function.Pi
- 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.
- PidDiscoverer - Interface in org.apache.druid.java.util.metrics
- 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.
- PLAN_VALIDATION_FAILED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- plus(String) - Method in class org.apache.druid.data.input.ColumnsFilter.ExclusionBased
- plus(String) - Method in class org.apache.druid.data.input.ColumnsFilter.InclusionBased
- plus(String) - Method in class org.apache.druid.data.input.ColumnsFilter
-
Returns a new filter with a particular column added.
- plus(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- PLUS - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- PLUS - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- 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
- PolyBind - Class in org.apache.druid.guice
-
Provides the ability to create "polymorphic" bindings where the polymorphism is actually just making a decision based on a value in Properties.
- PolyBind() - Constructor for class org.apache.druid.guice.PolyBind
- 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 areColumnCapabilities.isDictionaryEncoded()
andColumnCapabilities.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
- poolSize() - Method in class org.apache.druid.collections.StupidPool
- POPULATE_CACHE_KEY - Static variable in class org.apache.druid.query.QueryContexts
- POPULATE_RESULT_LEVEL_CACHE_KEY - Static variable in class org.apache.druid.query.QueryContexts
- populateBucketEntryForOffset(ReusableEntry<KeyType>, int) - Method in class org.apache.druid.query.groupby.epinephelinae.AbstractBufferHashGrouper
-
Populate a
ReusableEntry
with values from a particular bucket. - populateNullVector(boolean[], ReadableVectorOffset, PeekableIntIterator) - Static method in class org.apache.druid.segment.vector.VectorSelectorUtils
-
Helper used by ColumnarLongs, ColumnarDoubles, etc.
- populateTaskTypeAndGroupIdAsync() - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Utility to migrate existing tasks to the new schema by populating type and groupId asynchronously
- position() - Method in interface org.apache.druid.frame.field.ReadableFieldPointer
-
Starting position of the field.
- position() - Method in class org.apache.druid.frame.field.RowMemoryFieldPointer
- position() - Method in class org.apache.druid.frame.field.SettableFieldPointer
- position() - Method in class org.apache.druid.frame.segment.row.ConstantFrameRowPointer
- position() - Method in class org.apache.druid.frame.segment.row.CursorFrameRowPointer
- position() - Method in interface org.apache.druid.frame.segment.row.ReadableFrameRowPointer
-
Position of the start of the row relative to the start of the Frame
- position() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryPointer
- position(Integer) - Method in class org.apache.druid.frame.write.InvalidNullByteException.Builder
- possibleInDomain(Map<String, RangeSet<String>>) - Method in interface org.apache.druid.timeline.partition.BucketNumberedShardSpec
- possibleInDomain(Map<String, RangeSet<String>>) - Method in interface org.apache.druid.timeline.partition.BuildingShardSpec
- possibleInDomain(Map<String, RangeSet<String>>) - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
-
Set[:i] is the cartesian product of Set[0],...,Set[i - 1] EffectiveDomain[:i] is defined as QueryDomain[:i] INTERSECTION SegmentRange[:i] i = 1 If EffectiveDomain[:i] == {start[:i]} || EffectiveDomain == {end[:i]}: if i == index.dimensions.size: ACCEPT segment else: REPEAT with i = i + 1 else if EffectiveDomain[:i] == {}: PRUNE segment else: ACCEPT segment Example: Index on (Hour, Minute, Second).
- possibleInDomain(Map<String, RangeSet<String>>) - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- possibleInDomain(Map<String, RangeSet<String>>) - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- possibleInDomain(Map<String, RangeSet<String>>) - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- possibleInDomain(Map<String, RangeSet<String>>) - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- possibleInDomain(Map<String, RangeSet<String>>) - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- possibleInDomain(Map<String, RangeSet<String>>) - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
if given domain ranges are not possible in this shard, return false; otherwise return true;
- possibleInDomain(Map<String, RangeSet<String>>) - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- possibleInDomain(Map<String, RangeSet<String>>) - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- 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
- 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(Collection<PostAggregator>) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- postAggregators(List<PostAggregator>) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- postAggregators(PostAggregator...) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- postAggregators(PostAggregator...) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- postFilters(List<Filter>) - Method in interface org.apache.druid.query.QueryMetrics
-
Deprecated.use
QueryMetrics.filterBundle(FilterBundle.BundleInfo)
instead to collect details about filters which were used as value matchers forFilteredOffset
orFilteredVectorOffset
This method will be removed in a future Druid release - POSTGRES_DRIVER - Static variable in class org.apache.druid.utils.ConnectionUriUtils
- POSTGRES_PREFIX - Static variable in class org.apache.druid.utils.ConnectionUriUtils
- PostJoinCursor - Class in org.apache.druid.segment.join
-
A Cursor decorator used by
HashJoinSegmentStorageAdapter.makeCursors(org.apache.druid.query.filter.Filter, org.joda.time.Interval, org.apache.druid.segment.VirtualColumns, org.apache.druid.java.util.common.granularity.Granularity, boolean, org.apache.druid.query.QueryMetrics<?>)
to add post-join virtual columns and filters. - postMergeQueryDecoration(QueryRunner<Result<TopNResultValue>>) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
- postMergeQueryDecoration(QueryRunner<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
-
Wraps a QueryRunner.
- postProcess(Sequence<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupByQuery
-
Apply the havingSpec and limitSpec.
- postProcess(PostProcessingOperator<T>) - Method in class org.apache.druid.query.FluentQueryRunner
- 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
- Pow() - Constructor for class org.apache.druid.math.expr.Function.Pow
- POW - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- POW - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- power(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- PowOpExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.PowOpExprContext
- pQueue - Variable in class org.apache.druid.segment.AutoTypeColumnMerger.ArrayDictionaryMergingIterator
- pQueue - Variable in class org.apache.druid.segment.DictionaryMergingIterator
- pQueue - Variable in class org.apache.druid.segment.SimpleDictionaryMergingIterator
- PrebuiltDictionary(ColumnCapabilities, IntFunction<String>) - Constructor for class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.PrebuiltDictionary
- PRECOMPUTED_TYPE - Static variable in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
- PreComputedHyperUniquesSerde - Class in org.apache.druid.query.aggregation.hyperloglog
- PreComputedHyperUniquesSerde() - Constructor for class org.apache.druid.query.aggregation.hyperloglog.PreComputedHyperUniquesSerde
- predicateFactory - Variable in class org.apache.druid.segment.filter.DimensionPredicateFilter
- predicateFactory(ExtractionFn) - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
- PredicateFactory(List<?>, ColumnType) - Constructor for class org.apache.druid.query.filter.TypedInFilter.PredicateFactory
- predicateMatcherFactory - Variable in class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- PredicateValueMatcherFactory - Class in org.apache.druid.segment.filter
-
Creates
ValueMatcher
that apply a predicate to each value. - PredicateValueMatcherFactory(DruidPredicateFactory) - Constructor for class org.apache.druid.segment.filter.PredicateValueMatcherFactory
- preFilters(List<Filter>) - Method in interface org.apache.druid.query.QueryMetrics
-
Deprecated.use
QueryMetrics.filterBundle(FilterBundle.BundleInfo)
instead to collect details about filters which were used to constructBitmapOffset
orBitmapVectorOffset
. This method will be removed in a future Druid release - 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
- 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<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
- preMergeQueryDecoration(QueryRunner<ScanResultValue>) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
- preMergeQueryDecoration(QueryRunner<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
-
Wraps a QueryRunner.
- 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.
- prepareAggregations(List<AggregatorFactory>, List<PostAggregator>) - Static method in class org.apache.druid.query.Queries
-
Deprecated.
- 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
- prepareGroupByQuery(GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupingEngine
- prepareResource(GroupByQuery, BlockingPool<ByteBuffer>, boolean, GroupByQueryConfig) - Static method in class org.apache.druid.query.groupby.GroupingEngine
-
Initializes resources required to run
GroupByQueryQueryToolChest.mergeResults(QueryRunner)
andGroupByMergingQueryRunner
for a particular query. - prependAndBuild(String, Object...) - Method in exception org.apache.druid.error.DruidException
-
Builds a new DruidException with a message that is the result of prepending the message passed as a parameter with the message already on the DruidException.
- preserveExistingMetrics - Variable in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- preserveExistingMetrics - Variable in class org.apache.druid.segment.incremental.IncrementalIndex
- 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
-
If the
DimensionSpec.decorate(org.apache.druid.segment.DimensionSelector)
methods alter the underlying behavior of the dimension selector, does this alteration preserve the original ordering? - 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".
- print(DateTime) - Method in class org.apache.druid.java.util.common.DateTimes.UtcFormatter
- PrioritizedCallable<V> - Interface in org.apache.druid.query
- PrioritizedExecutorService - Class in org.apache.druid.query
- PrioritizedExecutorService(ThreadPoolExecutor, boolean, int, DruidProcessingConfig) - Constructor for class org.apache.druid.query.PrioritizedExecutorService
- PrioritizedExecutorService(ThreadPoolExecutor, DruidProcessingConfig) - Constructor for class org.apache.druid.query.PrioritizedExecutorService
- PrioritizedQueryRunnerCallable<T,V> - Interface in org.apache.druid.query
-
An implementation of
PrioritizedCallable
that also lets caller get access to associatedQueryRunner
It is used in implementations ofQueryRunnerFactory
- 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
- ProcCgroupDiscoverer - Class in org.apache.druid.java.util.metrics.cgroups
- ProcCgroupDiscoverer(Path) - Constructor for class org.apache.druid.java.util.metrics.cgroups.ProcCgroupDiscoverer
-
Create a proc discovery mechanism based on a `/proc` directory.
- process(Set<? extends TypeElement>, RoundEnvironment) - Method in class org.apache.druid.annotations.SubclassesMustBePublicAnnotationProcessor
- process(GroupByQuery, GroupByQuery, Sequence<ResultRow>, GroupByQueryConfig, DruidProcessingConfig, GroupByQueryResources, 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, DruidProcessingConfig, GroupByQueryMetrics) - Static method in class org.apache.druid.query.groupby.epinephelinae.vector.VectorGroupByEngine
- process(GroupByQuery, StorageAdapter, ByteBuffer, DateTime, GroupByQueryConfig, DruidProcessingConfig, Filter, Interval, GroupByQueryMetrics) - Static method in class org.apache.druid.query.groupby.epinephelinae.GroupByQueryEngine
- process(GroupByQuery, StorageAdapter, GroupByQueryMetrics) - Method in class org.apache.druid.query.groupby.GroupingEngine
-
Process a groupBy query on a single
StorageAdapter
. - process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.ComposingProcessor
- process(RowsAndColumns) - Method in interface org.apache.druid.query.operator.window.Processor
-
Applies the logic of the processor to a RowsAndColumns object
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.ranking.WindowCumeDistProcessor
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.ranking.WindowDenseRankProcessor
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.ranking.WindowPercentileProcessor
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.ranking.WindowRankProcessor
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.ranking.WindowRowNumberProcessor
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.value.WindowFirstProcessor
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.value.WindowLastProcessor
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.value.WindowOffsetProcessor
- process(RowsAndColumns) - Method in class org.apache.druid.query.operator.window.WindowFramedAggregateProcessor
- process(ScanQuery, Segment, ResponseContext, QueryMetrics<?>) - Method in class org.apache.druid.query.scan.ScanQueryEngine
- process(TimeseriesQuery, StorageAdapter, TimeseriesQueryMetrics) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryEngine
-
Run a single-segment, single-interval timeseries query on a particular adapter.
- PROCESS_ARRAYS_AS_MULTIVALUE_STRINGS_CONFIG_STRING - Static variable in class org.apache.druid.math.expr.ExpressionProcessingConfig
- processArrayField(ArrayList<NestedPathPart>, List<?>) - Method in class org.apache.druid.segment.nested.StructuredDataProcessor
-
Process a
List
orObject
returning aStructuredDataProcessor.ProcessedValue
if no further processing should be performed by theStructuredDataProcessor
, else a return value of null indicates that each element of the array will be processed separately as a newNestedPathArrayElement
part. - processArraysAsMultiValueStrings() - Static method in class org.apache.druid.math.expr.ExpressionProcessing
-
All
ExprType.ARRAY
values will be converted toExpressionType.STRING
by their column selectors (not within expression processing) to be treated as multi-value strings instead of native arrays. - processArraysAsMultiValueStrings() - Method in class org.apache.druid.math.expr.ExpressionProcessingConfig
- PROCESSED - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
- PROCESSED_BYTES - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
-
Number of bytes read by an ingestion task.
- PROCESSED_WITH_ERROR - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
- ProcessedValue(T, int) - Constructor for class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessedValue
- processField(ArrayList<NestedPathPart>, Object) - Method in class org.apache.druid.segment.nested.StructuredDataProcessor
- processFields(Object) - Method in class org.apache.druid.segment.nested.StructuredDataProcessor
-
Process some object, traversing any nested structure and returning a list of all paths which created a
StructuredDataProcessor.ProcessedValue
during processing, represented as an ordered sequence ofNestedPathPart
. - processHeaderLine(byte[]) - Method in class org.apache.druid.data.input.impl.DelimitedValueReader
- processHeaderLine(byte[]) - Method in class org.apache.druid.data.input.impl.JsonLineReader
- processHeaderLine(String) - Method in class org.apache.druid.data.input.impl.RegexReader
- processHeaderLine(T) - Method in class org.apache.druid.data.input.TextReader
-
Processes a header line.
- processIndex(TInput, TOutput, boolean[], int) - Method in class org.apache.druid.math.expr.vector.UnivariateFunctionVectorObjectProcessor
- processIndex(TLeftInput, boolean[], TRightInput, boolean[], int) - Method in class org.apache.druid.math.expr.vector.BivariateFunctionVectorProcessor
- processingFailed(Throwable, String, Object...) - Method in interface org.apache.druid.math.expr.NamedFunction
- processInternal(RowsAndColumns, Function<int[], Column>) - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- processInternal(RowsAndColumns, Function<Column, Column>) - Method in class org.apache.druid.query.operator.window.value.WindowValueProcessorBase
-
This implements the common logic between the various value processors.
- processMergedRow(ColumnValueSelector) - Method in class org.apache.druid.segment.AutoTypeColumnMerger
- processMergedRow(ColumnValueSelector) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- 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.NestedDataColumnMergerV4
- processMergedRow(ColumnValueSelector) - Method in class org.apache.druid.segment.NumericDimensionMergerV9
- processor() - Method in class org.apache.druid.frame.processor.manager.ProcessorAndCallback
- Processor - Interface in org.apache.druid.query.operator.window
-
A Processor is a bit of logic that processes a single RowsAndColumns object to produce a new RowsAndColumns object.
- ProcessorAndCallback<T> - Class in org.apache.druid.frame.processor.manager
-
Processor and success callback returned by
ProcessorManager.next()
. - ProcessorAndCallback(FrameProcessor<T>, Consumer<T>) - Constructor for class org.apache.druid.frame.processor.manager.ProcessorAndCallback
- ProcessorManager<T,R> - Interface in org.apache.druid.frame.processor.manager
-
Used by
FrameProcessorExecutor.runAllFully(org.apache.druid.frame.processor.manager.ProcessorManager<T, R>, int, org.apache.druid.frame.processor.Bouncer, java.lang.String)
to manage the launching of processors. - ProcessorManagers - Class in org.apache.druid.frame.processor.manager
-
Utility functions for creating
ProcessorManager
. - ProcessResults() - Constructor for class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
- processRowValsToUnsortedEncodedKeyComponent(Object, boolean) - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- processRowValsToUnsortedEncodedKeyComponent(Object, boolean) - Method in interface org.apache.druid.segment.DimensionIndexer
-
Encodes the given row value(s) of the dimension 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.NestedDataColumnIndexerV4
- processRowValsToUnsortedEncodedKeyComponent(Object, boolean) - Method in class org.apache.druid.segment.StringDimensionIndexer
- processSubqueryResult(GroupByQuery, GroupByQuery, GroupByQueryResources, Sequence<ResultRow>, boolean) - Method in class org.apache.druid.query.groupby.GroupingEngine
-
Called by
GroupByQueryQueryToolChest.mergeResults(QueryRunner)
when it needs to process a subquery. - processSubtotalsSpec(GroupByQuery, GroupByQueryResources, Sequence<ResultRow>) - Method in class org.apache.druid.query.groupby.GroupingEngine
-
Called by
GroupByQueryQueryToolChest.mergeResults(QueryRunner)
when it needs to generate subtotals. - processValue(Object) - Method in class org.apache.druid.segment.nested.ScalarDoubleColumnSerializer
- processValue(Object) - Method in class org.apache.druid.segment.nested.ScalarLongColumnSerializer
- processValue(Object) - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
-
Called during
ScalarNestedCommonFormatColumnSerializer.serialize(ColumnValueSelector)
to convert value to dictionary id. - processValue(Object) - Method in class org.apache.druid.segment.nested.ScalarStringColumnSerializer
- processValue(Object, Object) - Method in class org.apache.druid.math.expr.vector.ObjectOutObjectsInFunctionVectorProcessor
- processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FixedWidthGroupByColumnSelectorStrategy
- 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.KeyMappingMultiValueGroupByColumnSelectorStrategy.DictionaryBuilding
- processValueFromGroupingKey(GroupByColumnSelectorPlus, ByteBuffer, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.PrebuiltDictionary
- ProcFsReader - Class in org.apache.druid.java.util.metrics
-
Fetches data from top-level procfs files for metrics.
- ProcFsReader(Path) - Constructor for class org.apache.druid.java.util.metrics.ProcFsReader
- ProcSelfCgroupDiscoverer - Class in org.apache.druid.java.util.metrics.cgroups
- ProcSelfCgroupDiscoverer() - Constructor for class org.apache.druid.java.util.metrics.cgroups.ProcSelfCgroupDiscoverer
- progress - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- 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
- project(String...) - Method in class org.apache.druid.query.operator.join.JoinPartDefn.Builder
- PropertiesModule - Class in org.apache.druid.guice
- PropertiesModule(List<String>) - Constructor for class org.apache.druid.guice.PropertiesModule
- Property<T> - Class in org.apache.druid.indexer
-
Convenience class for holding a pair of string key and templated value.
- Property(String, T) - Constructor for class org.apache.druid.indexer.Property
- PROPERTY_BASE - Static variable in class org.apache.druid.guice.ExtensionsConfig
- PROPERTY_BASE - Static variable in class org.apache.druid.guice.ModulesConfig
- PROPERTY_BASE - Static variable in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- PROPERTY_BASE - Static variable in class org.apache.druid.metadata.MetadataStorageTablesConfig
- PropUtils - Class in org.apache.druid.common.utils
- PropUtils() - Constructor for class org.apache.druid.common.utils.PropUtils
- ProviderBasedGoogleSupplierProvider<T> - Class in org.apache.druid.guice
-
A Provider of a Supplier that uses a Provider to implement the Supplier.
- ProviderBasedGoogleSupplierProvider(Key<T>) - Constructor for class org.apache.druid.guice.ProviderBasedGoogleSupplierProvider
- pruneDependentPostAgg(List<PostAggregator>, String) - Static method in class org.apache.druid.query.aggregation.AggregatorUtil
-
Given a list of PostAggregators and the name of an output column, returns the minimal list of PostAggregators required to compute the output column.
- PruneLastCompactionState - Annotation Type in org.apache.druid.timeline
-
This annnotation is used to inject a boolean parameter into a
DataSegment
constructor, which prescribes to drop deserialized "lastCompactionState" and don't store it in a field of aDataSegment
. - PruneLoadSpec - Annotation Type in org.apache.druid.timeline
-
This annnotation is used to inject a boolean parameter into a
DataSegment
constructor, which prescribes to drop deserialized "loadSpec" and don't store it in a field of aDataSegment
. - PruneSpecsHolder() - Constructor for class org.apache.druid.timeline.DataSegment.PruneSpecsHolder
- PublicApi - Annotation Type in org.apache.druid.guice.annotations
-
Signifies that the annotated entity is a public API for extension authors.
- publishSegments(String, List<DataSegment>, ObjectMapper) - Method in interface org.apache.druid.indexer.MetadataStorageUpdaterJobHandler
- 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
- push(File, DataSegment, boolean) - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
-
Pushes index files and segment descriptor to deep storage.
- push(File, DataSegment, boolean) - Method in class org.apache.druid.segment.loading.NoopDataSegmentPusher
- push(RowsAndColumns) - Method in interface org.apache.druid.query.operator.Operator.Receiver
-
Used to push data.
- pushDownNot(Filter) - Static method in class org.apache.druid.segment.filter.cnf.HiveCnfHelper
- pushTaskLog(String, File) - Method in class org.apache.druid.tasklogs.NoopTaskLogs
- pushTaskLog(String, File) - Method in interface org.apache.druid.tasklogs.TaskLogPusher
- pushTaskPayload(String, File) - Method in class org.apache.druid.tasklogs.NoopTaskLogs
- pushTaskPayload(String, File) - Method in interface org.apache.druid.tasklogs.TaskPayloadManager
-
Save payload so it can be retrieved later.
- pushTaskReports(String, File) - Method in class org.apache.druid.tasklogs.NoopTaskLogs
- pushTaskReports(String, File) - Method in interface org.apache.druid.tasklogs.TaskLogPusher
- pushTaskStatus(String, File) - Method in class org.apache.druid.tasklogs.NoopTaskLogs
- pushTaskStatus(String, File) - Method in interface org.apache.druid.tasklogs.TaskLogPusher
- pushToPath(File, DataSegment, String) - Method in interface org.apache.druid.segment.loading.DataSegmentPusher
- pushToPath(File, DataSegment, String) - Method in class org.apache.druid.segment.loading.NoopDataSegmentPusher
- put(String, Object) - Method in class org.apache.druid.java.util.emitter.core.EventMap.Builder
-
Adds key -> value pair to the map
- put(ResponseContext.Key, Object) - Method in class org.apache.druid.query.context.ResponseContext
-
Associates the specified object with the specified extension key.
- putAll(Map<? extends String, ? extends Object>) - Method in class org.apache.druid.java.util.emitter.core.EventMap.Builder
-
Adds all key -> value pairs from other map
- putAll(Map<String, Object>) - Method in class org.apache.druid.segment.Metadata
- putBoolean(boolean) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putBoolean(long, boolean) - Method in class org.apache.druid.segment.data.SafeWritableBase
- putBooleanArray(boolean[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putBooleanArray(long, boolean[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- putByte(byte) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putByte(long, byte) - Method in class org.apache.druid.segment.data.SafeWritableBase
- putByteArray(byte[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putByteArray(long, byte[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- putChar(char) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putChar(long, char) - Method in class org.apache.druid.segment.data.SafeWritableBase
- putCharArray(char[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putCharArray(long, char[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- putCharsToUtf8(long, CharSequence) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- putDefaultValue(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.DoubleFirstLastVectorAggregator
- putDefaultValue(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
-
Sets the default value for the type in the byte buffer at the given position.
- putDefaultValue(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- putDefaultValue(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- putDefaultValue(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.SingleStringFirstLastDimensionVectorAggregator
- putDefaultValue(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastVectorAggregator
- putDouble(double) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putDouble(long, double) - Method in class org.apache.druid.segment.data.SafeWritableBase
- putDoubleArray(double[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putDoubleArray(long, double[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- putEntityTag(String) - Method in class org.apache.druid.query.context.ResponseContext
- 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);
- putFloat(float) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putFloat(long, float) - Method in class org.apache.druid.segment.data.SafeWritableBase
- putFloatArray(float[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putFloatArray(long, float[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- putIfAbsent(IncrementalIndexRow, int) - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
- putInt(int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putInt(long, int) - Method in class org.apache.druid.segment.data.SafeWritableBase
- putIntArray(int[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putIntArray(long, int[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- putLong(long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putLong(long, long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- putLongArray(long[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putLongArray(long, long[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- 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
- putNonNull(String, Object) - Method in class org.apache.druid.java.util.emitter.core.EventMap.Builder
-
Adds key -> value pair to the map only if value is not null
- putNull(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.DoubleFirstLastVectorAggregator
- putNull(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
- putNull(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- putNull(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- putNull(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.SingleStringFirstLastDimensionVectorAggregator
- putNull(ByteBuffer, int, long) - Method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastVectorAggregator
- putQueryFailDeadlineMs(long) - Method in class org.apache.druid.query.context.ResponseContext
- putShort(long, short) - Method in class org.apache.druid.segment.data.SafeWritableBase
- putShort(short) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putShortArray(long, short[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- putShortArray(short[], int, int) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- putTimeoutTime(long) - Method in class org.apache.druid.query.context.ResponseContext
- putUncoveredIntervals(List<Interval>, boolean) - Method in class org.apache.druid.query.context.ResponseContext
- putValue(ByteBuffer, int, long, Double) - Method in class org.apache.druid.query.aggregation.firstlast.DoubleFirstLastVectorAggregator
- putValue(ByteBuffer, int, long, Float) - Method in class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- putValue(ByteBuffer, int, long, Long) - Method in class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- putValue(ByteBuffer, int, long, String) - Method in class org.apache.druid.query.aggregation.firstlast.SingleStringFirstLastDimensionVectorAggregator
- putValue(ByteBuffer, int, long, String) - Method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastVectorAggregator
- putValue(ByteBuffer, int, long, VectorValueSelector, int) - Method in class org.apache.druid.query.aggregation.firstlast.DoubleFirstLastVectorAggregator
- putValue(ByteBuffer, int, long, VectorValueSelector, int) - Method in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
-
Sets the value represented by the valueSelector at the given index.
- putValue(ByteBuffer, int, long, VectorValueSelector, int) - Method in class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- putValue(ByteBuffer, int, long, VectorValueSelector, int) - Method in class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- putValue(ByteBuffer, int, long, VectorValueSelector, int) - Method in class org.apache.druid.query.aggregation.firstlast.SingleStringFirstLastDimensionVectorAggregator
- putValue(ByteBuffer, int, long, VectorValueSelector, int) - Method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastVectorAggregator
- putValue(ByteBuffer, int, long, RhsType) - Method in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
-
Sets the value at the position.
- 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
- QUARTER - org.apache.druid.java.util.common.granularity.GranularityType
- QUARTER - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- QUARTER - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- Queries - Class in org.apache.druid.query
- Queries() - Constructor for class org.apache.druid.query.Queries
- query - Variable in class org.apache.druid.query.search.SearchQueryExecutor
- 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(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- query(SearchQuerySpec) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- 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 aSequence
ofTopNResultValue
, with one of the fineTopNAlgorithm
available chosen based on the type of column being aggregated. - query(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
- query(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
-
Pulls all information from the query object into dimensions of future metrics.
- Query<T> - Interface in org.apache.druid.query
- QUERY_CANCELED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- QUERY_CAPACITY_EXCEEDED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- QUERY_FAIL_DEADLINE_MILLIS - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
Query fail time (current time + timeout).
- QUERY_ID - Static variable in class org.apache.druid.query.BaseQuery
- QUERY_INTERRUPTED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- QUERY_RESOURCE_ID - Static variable in class org.apache.druid.query.QueryContexts
- QUERY_RESULTS_DIR - Static variable in class org.apache.druid.frame.util.DurableStorageUtils
- QUERY_RUNTIME_FAILURE - org.apache.druid.query.QueryException.FailType
- QUERY_TIMEOUT_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- QUERY_TOTAL_BYTES_GATHERED - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
Query total bytes gathered.
- QUERY_UNSUPPORTED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- 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(VirtualColumns, boolean, ReadableOffset, ColumnCache) - Constructor for class org.apache.druid.segment.QueryableIndexColumnSelectorFactory
- QueryableIndexCursorSequenceBuilder - Class in org.apache.druid.segment
- QueryableIndexCursorSequenceBuilder(QueryableIndex, Interval, VirtualColumns, Filter, QueryMetrics<? extends Query>, long, long, boolean) - 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
- QueryableIndexRowsAndColumns - Class in org.apache.druid.query.rowsandcols.concrete
- QueryableIndexRowsAndColumns(QueryableIndex) - Constructor for class org.apache.druid.query.rowsandcols.concrete.QueryableIndexRowsAndColumns
- 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
- QueryableIndexVectorColumnSelectorFactory - Class in org.apache.druid.segment.vector
- QueryableIndexVectorColumnSelectorFactory(QueryableIndex, ReadableVectorOffset, ColumnCache, VirtualColumns) - Constructor for class org.apache.druid.segment.vector.QueryableIndexVectorColumnSelectorFactory
- QueryCapacityExceededException - Exception in org.apache.druid.query
-
This exception is for QueryResource and SqlResource to surface when a query is cast away after it hits a resource limit.
- QueryCapacityExceededException(int) - Constructor for exception org.apache.druid.query.QueryCapacityExceededException
- QueryCapacityExceededException(String, int) - Constructor for exception org.apache.druid.query.QueryCapacityExceededException
- QueryCapacityExceededException(String, String, String, String) - Constructor for exception org.apache.druid.query.QueryCapacityExceededException
- QueryContext - Class in org.apache.druid.query
-
Immutable holder for query context parameters with typed access methods.
- QueryContext(Map<String, Object>) - Constructor for class org.apache.druid.query.QueryContext
- 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.
- QueryException(String, String, String, String) - Constructor for exception org.apache.druid.query.QueryException
- QueryException(Throwable, String, String, String) - Constructor for exception org.apache.druid.query.QueryException
- QueryException(Throwable, String, String, String, String) - Constructor for exception org.apache.druid.query.QueryException
- QueryException.FailType - Enum in org.apache.druid.query
- QueryExceptionCompat - Class in org.apache.druid.error
-
A
DruidException.Failure
that serves to cover conversions fromQueryException
. - QueryExceptionCompat(QueryException) - Constructor for class org.apache.druid.error.QueryExceptionCompat
- QUERYGRANULARITY - org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
- queryId(String) - 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(String) - Method in interface org.apache.druid.query.QueryMetrics
-
Sets id of the given query as dimension.
- queryId(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- queryId(String) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- queryId(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- queryId(QueryType) - Method in class org.apache.druid.query.DefaultQueryMetrics
- queryId(QueryType) - Method in interface org.apache.druid.query.QueryMetrics
-
Sets
Query.getId()
of the given query as dimension. - 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 inQueryRunner
s. - QueryProcessingPool - Interface in org.apache.druid.query
-
This class implements the logic of how units of query execution run concurrently.
- QueryResourceId - Class in org.apache.druid.query
-
Wrapper class on the queryResourceId string.
- QueryResourceId(String) - Constructor for class org.apache.druid.query.QueryResourceId
- 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.
- QueryTimeoutException - Exception in org.apache.druid.query
-
This exception is thrown when a query does not finish before the configured query timeout.
- QueryTimeoutException() - Constructor for exception org.apache.druid.query.QueryTimeoutException
- QueryTimeoutException(String) - Constructor for exception org.apache.druid.query.QueryTimeoutException
- QueryTimeoutException(String, String) - Constructor for exception org.apache.druid.query.QueryTimeoutException
- QueryTimeoutException(String, String, String, String) - Constructor for exception org.apache.druid.query.QueryTimeoutException
- 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(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- 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. - QueryUnsupportedException - Exception in org.apache.druid.query
-
This exception is for the query engine to surface when a query cannot be run.
- QueryUnsupportedException(String) - Constructor for exception org.apache.druid.query.QueryUnsupportedException
- QueryUnsupportedException(String, String, String, 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) - Constructor for class org.apache.druid.collections.spatial.search.RadiusBound
- RadiusBound(float[], float, int) - Constructor for class org.apache.druid.collections.spatial.search.RadiusBound
- RadiusBound(float[], float, int, RadiusBound.RadiusUnit) - Constructor for class org.apache.druid.collections.spatial.search.RadiusBound
- RadiusBound(float[], float, RadiusBound.RadiusUnit) - Constructor for class org.apache.druid.collections.spatial.search.RadiusBound
- RadiusBound.RadiusUnit - Enum in org.apache.druid.collections.spatial.search
- 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.topn.TopNQueryBuilder
- RANGE - org.apache.druid.indexer.partitions.SecondaryPartitionType
-
Range partitioning partitions segments in the same time chunk based on the value range of the partition dimension.
- RANGE - org.apache.druid.query.operator.window.WindowFrame.PeerType
- RANGE - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- RangeFilter - Class in org.apache.druid.query.filter
- RangeFilter(String, ColumnType, Object, Object, Boolean, Boolean, FilterTuning) - Constructor for class org.apache.druid.query.filter.RangeFilter
- RangeFilter.RangeType - Enum in org.apache.druid.query.filter
- 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
- RangeIntSet - Class in org.apache.druid.collections
-
Set from start (inclusive) to end (exclusive).
- RangeIntSet(int, int) - Constructor for class org.apache.druid.collections.RangeIntSet
- ranges() - Method in class org.apache.druid.frame.key.ClusterByPartitions
- rangeSet(int) - Static method in class org.apache.druid.frame.processor.FrameProcessors
-
Creates a mutable sorted set from 0 to "size" (exclusive).
- raw() - Method in class org.apache.druid.audit.AuditEntry.Payload
- RAW_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- RAW_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- RawFieldColumnSelector(ColumnValueSelector, List<NestedPathPart>) - Constructor for class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldColumnSelector
- RawFieldLiteralColumnValueSelector(ColumnValueSelector, List<NestedPathPart>) - Constructor for class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldLiteralColumnValueSelector
- RawFieldVectorObjectSelector(VectorObjectSelector, List<NestedPathPart>) - Constructor for class org.apache.druid.segment.virtual.NestedFieldVirtualColumn.RawFieldVectorObjectSelector
- RE - Exception in org.apache.druid.java.util.common
- RE(String, Object...) - Constructor for exception org.apache.druid.java.util.common.RE
- RE(Throwable) - Constructor for exception org.apache.druid.java.util.common.RE
- RE(Throwable, String, Object...) - Constructor for exception org.apache.druid.java.util.common.RE
- read() - Method in class org.apache.druid.data.input.impl.RetryingInputStream
- read() - Method in interface org.apache.druid.data.input.InputEntityReader
- read() - Method in interface org.apache.druid.data.input.InputSourceReader
- read() - Method in class org.apache.druid.data.input.IntermediateRowParsingReader
- read() - Method in class org.apache.druid.frame.channel.ComposingReadableFrameChannel
- read() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
- read() - Method in class org.apache.druid.frame.channel.ReadableConcatFrameChannel
- read() - Method in class org.apache.druid.frame.channel.ReadableFileFrameChannel
- read() - Method in interface org.apache.druid.frame.channel.ReadableFrameChannel
-
Returns the next available frame from this channel.
- read() - Method in class org.apache.druid.frame.channel.ReadableInputStreamFrameChannel
- read() - Method in class org.apache.druid.frame.channel.ReadableNilFrameChannel
- read() - Method in class org.apache.druid.io.ByteBufferInputStream
- read() - Method in class org.apache.druid.java.util.http.client.io.AppendableByteArrayInputStream
- read() - Method in class org.apache.druid.segment.transform.TransformingInputEntityReader
- read(byte[]) - Method in class org.apache.druid.data.input.impl.RetryingInputStream
- read(byte[], int, int) - Method in class org.apache.druid.data.input.impl.RetryingInputStream
- read(byte[], int, int) - Method in class org.apache.druid.io.ByteBufferInputStream
- read(byte[], int, int) - Method in class org.apache.druid.java.util.http.client.io.AppendableByteArrayInputStream
- read(int) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
- read(int) - Method in class org.apache.druid.segment.data.DeltaLongEncodingReader
- read(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(long[], int, int[], int, int, int) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
- read(long[], int, int[], int, int, int) - Method in class org.apache.druid.segment.data.DeltaLongEncodingReader
- read(long[], int, int[], int, int, int) - Method in class org.apache.druid.segment.data.LongsLongEncodingReader
- read(long[], int, int[], int, int, int) - Method in class org.apache.druid.segment.data.TableLongEncodingReader
- read(long[], int, int, int) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingReader
- read(long[], int, int, int) - Method in class org.apache.druid.segment.data.DeltaLongEncodingReader
- read(long[], int, int, int) - Method in class org.apache.druid.segment.data.LongsLongEncodingReader
- read(long[], int, int, int) - Method in class org.apache.druid.segment.data.TableLongEncodingReader
- read(long, int) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadReader
- read(String) - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
- read(String) - Method in class org.apache.druid.storage.NilStorageConnector
- read(String) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnector
- read(String) - Method in interface org.apache.druid.storage.StorageConnector
-
Reads the data present at the path in the underlying storage system.
- read(ByteBuffer) - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- read(ByteBuffer) - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- read(ByteBuffer) - Method in class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
- read(ByteBuffer) - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- read(ByteBuffer) - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- read(ByteBuffer) - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- read(ByteBuffer) - Method in class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- read(ByteBuffer) - Method in interface org.apache.druid.segment.column.TypeStrategy
-
Read a non-null value from the
ByteBuffer
at the currentBuffer.position()
. - read(ByteBuffer, int) - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- read(ByteBuffer, int) - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- read(ByteBuffer, int) - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- read(ByteBuffer, int) - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- read(ByteBuffer, int) - Method in interface org.apache.druid.segment.column.TypeStrategy
-
Read a non-null value from the
ByteBuffer
at the requested position. - read(ByteBuffer, int) - Static method in class org.apache.druid.segment.nested.FieldTypeInfo
- read(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.FrontCodedIndexed
- read(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexed
- read(ByteBuffer, ColumnBuilder, ColumnConfig) - Method in interface org.apache.druid.segment.serde.ColumnPartSerde.Deserializer
- read(ByteBuffer, ColumnBuilder, ColumnConfig, ObjectMapper) - Static method in class org.apache.druid.segment.nested.NestedDataColumnSupplierV4
- read(ByteBuffer, ColumnBuilder, ColumnConfig, ObjectMapper, TypeStrategy<Long>, TypeStrategy<Double>) - Static method in class org.apache.druid.segment.nested.NestedDataColumnSupplierV4
- read(ByteBuffer, ColumnConfig, SmooshedFileMapper) - Method in class org.apache.druid.segment.column.ColumnDescriptor
- read(ByteBuffer, TypeStrategy<T>, ByteOrder, int) - Static method in class org.apache.druid.segment.data.FixedIndexed
- 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(ByteOrder, BitmapSerdeFactory, ByteBuffer, ColumnBuilder) - Static method in class org.apache.druid.segment.nested.ScalarStringColumnAndIndexSupplier
- read(ByteOrder, BitmapSerdeFactory, ByteBuffer, ColumnBuilder, ColumnConfig) - Static method in class org.apache.druid.segment.nested.ScalarDoubleColumnAndIndexSupplier
- read(ByteOrder, BitmapSerdeFactory, ByteBuffer, ColumnBuilder, ColumnConfig) - Static method in class org.apache.druid.segment.nested.ScalarLongColumnAndIndexSupplier
- read(InputStats) - Method in class org.apache.druid.data.input.impl.InputEntityIteratingReader
- read(InputStats) - Method in class org.apache.druid.data.input.impl.TimedShutoffInputSourceReader
- read(InputStats) - Method in interface org.apache.druid.data.input.InputSourceReader
- read(InputStats) - Method in class org.apache.druid.segment.transform.TransformingInputSourceReader
- read(RowKey) - Method in class org.apache.druid.frame.key.RowKeyReader
-
Read all values out of a key, as a list of objects.
- read(RowKey, int) - Method in class org.apache.druid.frame.key.RowKeyReader
-
Read a value out of a key.
- read(ColumnType, boolean, ByteBuffer, ColumnBuilder, ColumnConfig, BitmapSerdeFactory, ByteOrder) - Static method in class org.apache.druid.segment.nested.NestedDataColumnSupplier
- read(ColumnType, ByteOrder, BitmapSerdeFactory, ByteBuffer, ColumnBuilder) - Static method in class org.apache.druid.segment.nested.VariantColumnAndIndexSupplier
- readabilityFuture() - Method in class org.apache.druid.frame.channel.ComposingReadableFrameChannel
- readabilityFuture() - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
- readabilityFuture() - Method in class org.apache.druid.frame.channel.ReadableConcatFrameChannel
- readabilityFuture() - Method in class org.apache.druid.frame.channel.ReadableFileFrameChannel
- readabilityFuture() - Method in interface org.apache.druid.frame.channel.ReadableFrameChannel
-
Returns a future that will resolve when either
ReadableFrameChannel.isFinished()
orReadableFrameChannel.canRead()
would return true. - readabilityFuture() - Method in class org.apache.druid.frame.channel.ReadableInputStreamFrameChannel
- readabilityFuture() - Method in class org.apache.druid.frame.channel.ReadableNilFrameChannel
- readable() - Method in class org.apache.druid.frame.channel.BlockingQueueFrameChannel
-
Returns the readable side of this channel.
- ReadableByteChunksFrameChannel - Class in org.apache.druid.frame.channel
-
Channel backed by a byte stream that is continuously streamed in using
ReadableByteChunksFrameChannel.addChunk(byte[])
. - ReadableConcatFrameChannel - Class in org.apache.druid.frame.channel
-
Channel that concatenates a sequence of other channels that are provided by an iterator.
- ReadableFieldPointer - Interface in org.apache.druid.frame.field
-
Pointer to a field position in some memory.
- ReadableFileFrameChannel - Class in org.apache.druid.frame.channel
-
Channel backed by a
FrameFile
. - ReadableFileFrameChannel(FrameFile) - Constructor for class org.apache.druid.frame.channel.ReadableFileFrameChannel
- ReadableFileFrameChannel(FrameFile, int, int) - Constructor for class org.apache.druid.frame.channel.ReadableFileFrameChannel
- ReadableFrameChannel - Interface in org.apache.druid.frame.channel
-
Interface for reading a sequence of frames.
- ReadableFrameRowPointer - Interface in org.apache.druid.frame.segment.row
-
Pointer to a row position in some memory.
- ReadableInputStreamFrameChannel - Class in org.apache.druid.frame.channel
-
Channel backed by an
InputStream
. - ReadableNilFrameChannel - Class in org.apache.druid.frame.channel
-
Empty channel.
- 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.
- ReadableVectorInspector - Interface in org.apache.druid.segment.vector
-
Vector inspector that can supply a unique identifier of the vector to use with caching in addition to sizing information
- ReadableVectorMatch - Interface in org.apache.druid.query.filter.vector
-
The result of calling
VectorValueMatcher.match(org.apache.druid.query.filter.vector.ReadableVectorMatch, boolean)
. - ReadableVectorOffset - Interface in org.apache.druid.segment.vector
-
Provides a batch of offsets, ostensibly as indexes into an array.
- readByteBuffer(Memory, long, int) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
-
Returns a ByteBuffer containing data from the provided
Memory
. - readBytes(ByteBuffer, int) - Method in class org.apache.druid.common.utils.SerializerUtils
- readColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.ComplexFrameColumnReader
- readColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.DoubleFrameColumnReader
- readColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.FloatFrameColumnReader
- readColumn(Frame) - Method in interface org.apache.druid.frame.read.columnar.FrameColumnReader
-
Returns a column reference for the provided frame.
- readColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.LongFrameColumnReader
- readColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader
- readColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.StringFrameColumnReader
- readColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.UnsupportedColumnTypeFrameColumnReader
- readComparableLong(Memory, long, int) - Static method in class org.apache.druid.frame.read.FrameReaderUtils
- readDoublePairFromVectorSelectors(boolean[], long[], Object[], int) - Static method in class org.apache.druid.query.aggregation.firstlast.FirstLastUtils
- reader(InputRowSchema, InputFormat, File) - Method in class org.apache.druid.data.input.AbstractInputSource
- reader(InputRowSchema, InputFormat, File) - Method in interface org.apache.druid.data.input.InputSource
-
Creates an
InputSourceReader
. - readField(Memory, long, long, int) - Method in class org.apache.druid.frame.field.RowReader
-
Read a particular field value as an object.
- readFieldFromByteArray(ComplexMetricSerde, byte[], int) - Static method in class org.apache.druid.frame.field.ComplexFieldReader
-
Alternative interface to read the field from the byte array without creating a selector and field pointer.
- readFieldFromMemory(ComplexMetricSerde, Memory, long) - Static method in class org.apache.druid.frame.field.ComplexFieldReader
-
Alternative interface to read the field from the memory without creating a selector and field pointer
- readFloatPairFromVectorSelectors(boolean[], long[], Object[], int) - Static method in class org.apache.druid.query.aggregation.firstlast.FirstLastUtils
- readFrom(long) - Method in class org.apache.druid.data.input.impl.HttpEntity
- readFrom(long) - Method in class org.apache.druid.data.input.RetryingInputEntity
-
Directly opens an
InputStream
starting at the given offset on the input entity. - readFromByteBuffer(ByteBuffer) - Static method in class org.apache.druid.segment.data.VSizeColumnarInts
- readFromByteBuffer(ByteBuffer) - Static method in class org.apache.druid.segment.data.VSizeColumnarMultiInts
- readFromByteBuffer(T, ByteBuffer, int) - Method in interface org.apache.druid.query.groupby.epinephelinae.Grouper.KeySerde
-
Deserialize a key from a buffer.
- readFromStart() - Method in class org.apache.druid.data.input.RetryingInputEntity
-
Directly opens an
InputStream
on the input entity. - 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.
- readInt(ByteBuffer) - Static method in class org.apache.druid.segment.data.VByte
-
Read a variable byte (vbyte) encoded integer from a
ByteBuffer
at the current position. - readKey(int) - Method in interface org.apache.druid.frame.key.FrameComparisonWidget
-
Returns the
RowKey
corresponding to a particular row. - readKey(int) - Method in class org.apache.druid.frame.key.FrameComparisonWidgetImpl
-
Creates
RowKey
from a row in the frame. - readLongPairFromVectorSelectors(boolean[], long[], Object[], int) - Static method in class org.apache.druid.query.aggregation.firstlast.FirstLastUtils
- readNotNullNullableDouble(ByteBuffer, int) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Reads a non-null double value from a
ByteBuffer
at the supplied offset. - readNotNullNullableFloat(ByteBuffer, int) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Reads a non-null float value from a
ByteBuffer
at the supplied offset. - readNotNullNullableLong(ByteBuffer, int) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Reads a non-null long value from a
ByteBuffer
at the supplied offset. - readOnly() - Method in class org.apache.druid.frame.processor.OutputChannel
-
Returns a read-only version of this instance.
- readOnly() - Method in class org.apache.druid.frame.processor.OutputChannels
-
Returns a read-only version of this instance.
- readOnly() - Method in class org.apache.druid.frame.processor.PartitionedOutputChannel
-
Returns a read-only version of this instance.
- readOnly(Supplier<ReadableFrameChannel>, int) - Static method in class org.apache.druid.frame.processor.OutputChannel
-
Creates a read-only output channel.
- readOnly(ReadableFrameChannel, int) - Static method in class org.apache.druid.frame.processor.OutputChannel
-
Creates a read-only output channel.
- readPair(ByteBuffer, int) - Static method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastUtils
- readPairFromSelectors(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>) - Static method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastUtils
- readPairFromVectorSelectors(boolean[], long[], Object[], int) - Method in class org.apache.druid.query.aggregation.firstlast.DoubleFirstLastVectorAggregator
- readPairFromVectorSelectors(boolean[], long[], Object[], int) - Method in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
- readPairFromVectorSelectors(boolean[], long[], Object[], int) - Method in class org.apache.druid.query.aggregation.firstlast.FloatFirstLastVectorAggregator
- readPairFromVectorSelectors(boolean[], long[], Object[], int) - Method in class org.apache.druid.query.aggregation.firstlast.LongFirstLastVectorAggregator
- readPairFromVectorSelectors(boolean[], long[], Object[], int) - Method in class org.apache.druid.query.aggregation.firstlast.SingleStringFirstLastDimensionVectorAggregator
- readPairFromVectorSelectors(boolean[], long[], Object[], int) - Method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastVectorAggregator
- readPairFromVectorSelectorsAtIndex(boolean[], long[], Object[], int) - Static method in class org.apache.druid.query.aggregation.firstlast.StringFirstLastUtils
-
Return the object at a particular index from the vector selectors.
- readRACColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.ComplexFrameColumnReader
- readRACColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.DoubleFrameColumnReader
- readRACColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.FloatFrameColumnReader
- readRACColumn(Frame) - Method in interface org.apache.druid.frame.read.columnar.FrameColumnReader
-
Returns a
Column
from the frame. - readRACColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.LongFrameColumnReader
- readRACColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.NumericArrayFrameColumnReader
- readRACColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.StringFrameColumnReader
- readRACColumn(Frame) - Method in class org.apache.druid.frame.read.columnar.UnsupportedColumnTypeFrameColumnReader
- readRange(String, long, long) - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
- readRange(String, long, long) - Method in class org.apache.druid.storage.NilStorageConnector
- readRange(String, long, long) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnector
- readRange(String, long, long) - Method in interface org.apache.druid.storage.StorageConnector
-
Reads the data present for a given range at the path in the underlying storage system.
- readRetainsBufferReference() - Method in class org.apache.druid.segment.column.NullableTypeStrategy
-
Whether the
NullableTypeStrategy.read(java.nio.ByteBuffer)
methods return an object that may retain a reference to the providedByteBuffer
. - readRetainsBufferReference() - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- readRetainsBufferReference() - Method in class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
- readRetainsBufferReference() - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- readRetainsBufferReference() - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- readRetainsBufferReference() - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- readRetainsBufferReference() - Method in class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- readRetainsBufferReference() - Method in interface org.apache.druid.segment.column.TypeStrategy
-
Whether the
TypeStrategy.read(java.nio.ByteBuffer)
methods return an object that may retain a reference to the providedByteBuffer
. - readRow(Memory, long, long) - Method in class org.apache.druid.frame.field.RowReader
-
Read an entire row as a list of objects.
- readString(ByteBuffer) - Method in class org.apache.druid.common.utils.SerializerUtils
- readValue(JsonParser) - Method in class org.apache.druid.query.context.ResponseContext.AbstractKey
- readValue(JsonParser) - Method in interface org.apache.druid.query.context.ResponseContext.Key
-
Reads a value of this key from a JSON stream.
- readValue(ObjectMapper, byte[], TypeReference<T>) - Static method in class org.apache.druid.java.util.common.jackson.JacksonUtils
-
Silences Jackson's
IOException
. - readValue(ObjectMapper, byte[], JavaType) - Static method in class org.apache.druid.java.util.common.jackson.JacksonUtils
-
Silences Jackson's
IOException
. - readValue(ObjectMapper, byte[], Class<T>) - Static method in class org.apache.druid.java.util.common.jackson.JacksonUtils
-
Silences Jackson's
IOException
. - READY - org.apache.druid.timeline.LogicalSegment.Status
- 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
- RearrangedRowsAndColumns - Class in org.apache.druid.query.rowsandcols
-
This class exists to "decorate" a rows and columns such that it pretends to exist in a new ordering.
- RearrangedRowsAndColumns(int[], int, int, RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.RearrangedRowsAndColumns
- RearrangedRowsAndColumns(int[], RowsAndColumns) - Constructor for class org.apache.druid.query.rowsandcols.RearrangedRowsAndColumns
- RectangularBound - Class in org.apache.druid.collections.spatial.search
- RectangularBound(float[], float[]) - Constructor for class org.apache.druid.collections.spatial.search.RectangularBound
- RectangularBound(float[], float[], int) - 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
- ReferenceCountingResourceHolder<T> - Class in org.apache.druid.collections
- ReferenceCountingResourceHolder(T, Closeable) - Constructor for class org.apache.druid.collections.ReferenceCountingResourceHolder
- ReferenceCountingSegment - Class in org.apache.druid.segment
-
Segment
that is also aReferenceCountingSegment
, allowing query engines that operate directly on segments to track references so that dropping aSegment
can be done safely to ensure there are no in-flight queries. - ReferenceCountingSegment(Segment, int, int, short, short) - Constructor for class org.apache.druid.segment.ReferenceCountingSegment
- 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, Boolean, String) - Constructor for class org.apache.druid.query.extraction.RegexDimExtractionFn
- RegexDimExtractionFn(String, Integer, Boolean, String) - Constructor for class org.apache.druid.query.extraction.RegexDimExtractionFn
- RegexDimFilter - Class in org.apache.druid.query.filter
- RegexDimFilter(String, String, ExtractionFn) - Constructor for class org.apache.druid.query.filter.RegexDimFilter
- RegexDimFilter(String, String, ExtractionFn, FilterTuning) - 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
- RegexInputFormat - Class in org.apache.druid.data.input.impl
- RegexInputFormat(String, String, List<String>) - Constructor for class org.apache.druid.data.input.impl.RegexInputFormat
- RegexParser - Class in org.apache.druid.java.util.common.parsers
- RegexParser(String, Optional<String>) - Constructor for class org.apache.druid.java.util.common.parsers.RegexParser
- RegexParser(String, Optional<String>, Iterable<String>) - Constructor for class org.apache.druid.java.util.common.parsers.RegexParser
- RegexParseSpec - Class in org.apache.druid.data.input.impl
- RegexParseSpec(TimestampSpec, DimensionsSpec, String, List<String>, String) - Constructor for class org.apache.druid.data.input.impl.RegexParseSpec
- 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
- RegexpReplaceExprMacro - Class in org.apache.druid.query.expression
- RegexpReplaceExprMacro() - Constructor for class org.apache.druid.query.expression.RegexpReplaceExprMacro
- RegexReader - Class in org.apache.druid.data.input.impl
- RegexSearchQuerySpec - Class in org.apache.druid.query.search
- RegexSearchQuerySpec(String) - Constructor for class org.apache.druid.query.search.RegexSearchQuerySpec
- region() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- region(int) - Method in class org.apache.druid.frame.Frame
-
Returns memory corresponding to a particular region of this frame.
- region(long, long, ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- region(long, long, ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- register(C) - Method in class org.apache.druid.java.util.common.io.Closer
- register(Binder, Class<?>) - Static method in class org.apache.druid.guice.LifecycleModule
-
Registers a class to instantiate eagerly.
- register(Binder, Class<?>, Class<? extends Annotation>) - Static method in class org.apache.druid.guice.LifecycleModule
-
Registers a class/annotation combination to instantiate eagerly.
- register(Object, Runnable) - Method in interface org.apache.druid.java.util.common.Cleaners.Cleaner
- register(Object, Runnable) - Static method in class org.apache.druid.java.util.common.Cleaners
- REGISTER_OFFSET_BYTE - Static variable in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- registerAll(Collection<C>) - Method in class org.apache.druid.java.util.common.io.Closer
- registerComplex(String, TypeStrategy<?>) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
hmm...
- registerDimensionHandlerProvider(String, DimensionHandlerProvider) - Static method in class org.apache.druid.segment.DimensionHandlerUtils
- RegisteredLookupExtractionFn - Class in org.apache.druid.query.lookup
- RegisteredLookupExtractionFn(LookupExtractorFactoryContainerProvider, String, boolean, String, Boolean, Boolean) - Constructor for class org.apache.druid.query.lookup.RegisteredLookupExtractionFn
- registerEmitter(ServiceEmitter) - Static method in class org.apache.druid.java.util.emitter.EmittingLogger
- registerHandler(DefaultColumnFormatConfig) - Method in class org.apache.druid.guice.NestedDataModule
- registerHandlersAndSerde() - Static method in class org.apache.druid.guice.NestedDataModule
-
Helper for wiring stuff up for tests
- registerKey(Binder, Key<?>) - Static method in class org.apache.druid.guice.LifecycleModule
-
Registers a key to instantiate eagerly.
- registerKey(ResponseContext.Key) - Method in class org.apache.druid.query.context.ResponseContext.Keys
-
Primary way of registering context keys.
- registerKeys(ResponseContext.Key[]) - Method in class org.apache.druid.query.context.ResponseContext.Keys
-
Register a group of 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
- release(long) - Method in class org.apache.druid.frame.channel.ByteTracker
- 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
- rem - Variable in class org.apache.druid.segment.data.FrontCodedIndexed
- remainder(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Remainder() - Constructor for class org.apache.druid.math.expr.Function.Remainder
- REMAINING_RESPONSES_FROM_QUERY_SERVERS - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
Map of most relevant query ID to remaining number of responses from query nodes.
- remainingCapacity() - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
- 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() - Method in class org.apache.druid.collections.CombiningIterator
- remove() - Method in class org.apache.druid.collections.IntegerSet.BitSetIterator
- remove() - Method in class org.apache.druid.java.util.common.guava.DroppingIterator
- remove() - Method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- remove() - Method in class org.apache.druid.java.util.common.guava.MergeIterator
- remove() - Method in class org.apache.druid.java.util.common.guava.nary.TrinaryTransformIterator
- 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.AutoTypeColumnMerger.ArrayDictionaryMergingIterator
- remove() - Method in class org.apache.druid.segment.DictionaryMergingIterator
- remove() - Method in class org.apache.druid.segment.SimpleDictionaryMergingIterator
- 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(int) - Method in class org.apache.druid.extendedset.intset.ConciseSet
- remove(Object) - Method in class org.apache.druid.collections.IntegerSet
- remove(ResponseContext.Key) - Method in class org.apache.druid.query.context.ResponseContext
- remove(PartitionChunk<T>) - Method in class org.apache.druid.timeline.partition.PartitionHolder
- remove(Interval, VersionType, PartitionChunk<ObjectType>) - Method in class org.apache.druid.timeline.VersionedIntervalTimeline
- 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
- removeAuditLogsOlderThan(long) - Method in interface org.apache.druid.audit.AuditManager
-
Remove audit logs created older than the given timestamp.
- removeChar(String, char) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Removes all occurrences of the given char from the given string.
- removeLock(long) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Remove the lock with the given lock id.
- removeMax() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
- removeMin() - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
- removeMonitor(Monitor) - Method in class org.apache.druid.java.util.metrics.MonitorScheduler
- removeOffset(int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
- removeProperty(Object, Object) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- removeTasksOlderThan(long) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Remove the tasks created older than the given timestamp.
- repeat(String, int) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Returns a string whose value is the concatenation of the string
s
repeatedcount
times. - REPEAT - org.apache.druid.java.util.common.concurrent.ScheduledExecutors.Signal
- RepeatFunc() - Constructor for class org.apache.druid.math.expr.Function.RepeatFunc
- replace(String, String, String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Replaces all occurrences of the given target substring in the given string with the given replacement string.
- replaceChar(String, char, String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Replaces all occurrences of the given char in the given string with the given replacement string.
- ReplaceFirstValueWithNullIndexed<T> - Class in org.apache.druid.segment.serde
-
An Indexed that replaces the first value with a literal null.
- ReplaceFirstValueWithNullIndexed(Indexed<T>) - Constructor for class org.apache.druid.segment.serde.ReplaceFirstValueWithNullIndexed
- ReplaceFunc() - Constructor for class org.apache.druid.math.expr.Function.ReplaceFunc
- replaceLock(String, long, LockType) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Replace an existing lock with a new lock.
- replaces(LookupExtractorFactory) - Method in interface org.apache.druid.query.lookup.LookupExtractorFactory
-
Deprecated.
- replaces(LookupExtractorFactoryContainer) - Method in class org.apache.druid.query.lookup.LookupExtractorFactoryContainer
- replaceUnknownTypesWithNestedColumns(RowSignature) - Static method in class org.apache.druid.frame.write.FrameWriterUtils
- replaceWithDefault() - Static method in class org.apache.druid.common.config.NullHandling
-
whether nulls should be replaced with default value.
- REPORT_KEY - Static variable in class org.apache.druid.indexer.report.IngestionStatsAndErrorsTaskReport
- REPORT_KEY - Static variable in class org.apache.druid.indexer.report.KillTaskReport
- REPORT_KEY - Static variable in class org.apache.druid.indexer.report.TaskContextReport
- 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.filterBundle(FilterBundle.BundleInfo)
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
- ReportMap() - Constructor for class org.apache.druid.indexer.report.TaskReport.ReportMap
- 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
- reportParallelMergeFastestPartitionTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
- reportParallelMergeFastestPartitionTime(long) - Method in interface org.apache.druid.query.QueryMetrics
-
Reports broker "wall" time in nanoseconds for the fastest parallel merge sequence partition to be 'initialized', where 'initialized' is time to the first result batch is populated from data servers and merging can begin.
- reportParallelMergeFastestPartitionTime(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
- reportParallelMergeSlowestPartitionTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
- reportParallelMergeSlowestPartitionTime(long) - Method in interface org.apache.druid.query.QueryMetrics
-
Reports broker "wall" time in nanoseconds for the slowest parallel merge sequence partition to be 'initialized', where 'initialized' is time to the first result batch is populated from data servers and merging can begin.
- reportParallelMergeSlowestPartitionTime(long) - 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
- reportParallelMergeTotalTime(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
- reportParallelMergeTotalTime(long) - Method in interface org.apache.druid.query.QueryMetrics
-
Reports broker total "wall" time in nanoseconds from parallel merge start sequence creation to total consumption.
- reportParallelMergeTotalTime(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.filterBundle(FilterBundle.BundleInfo)
. - reportPreFilteredRows(long) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- reportQueriedSegmentCount(long) - Method in class org.apache.druid.query.DefaultQueryMetrics
- reportQueriedSegmentCount(long) - Method in interface org.apache.druid.query.QueryMetrics
-
Registers "segments queried count" metric.
- reportQueriedSegmentCount(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(List<SegmentDescriptor>) - Constructor for class org.apache.druid.query.ReportTimelineMissingSegmentQueryRunner
- ReportTimelineMissingSegmentQueryRunner(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
- request(RequestInfo) - Method in class org.apache.druid.audit.AuditEntry.Builder
- Request - Class in org.apache.druid.java.util.http.client
- Request(HttpMethod, URL) - Constructor for class org.apache.druid.java.util.http.client.Request
- RequestInfo - Class in org.apache.druid.audit
-
Contains information about a REST API request that was audited.
- RequestInfo(String, String, String, String) - Constructor for class org.apache.druid.audit.RequestInfo
- requiredBufferCapacity(int, AggregatorFactory[]) - Static method in class org.apache.druid.query.groupby.epinephelinae.BufferArrayGrouper
-
Computes required buffer capacity for a grouping key of the given cardinaltiy and aggregatorFactories.
- 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.frame.util.SettableLongVirtualColumn
- requiredColumns() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- requiredColumns() - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- requiredColumns() - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- requiredColumns() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- 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.ExpressionLambdaAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- 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.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.SingleValueAggregatorFactory
- requiredFields() - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- reseedRandomGenerator(long) - Method in class org.apache.druid.segment.generator.RealRoundingDistribution
- reserve(long) - Method in class org.apache.druid.frame.channel.ByteTracker
- reserve(QueryResourceId, GroupByQuery, boolean) - Method in class org.apache.druid.query.groupby.GroupByResourcesReservationPool
-
Reserves appropriate resources, and maps it to the queryResourceId (usually the query's resource id) in the internal map.
- reserveAdditional(int) - Method in class org.apache.druid.frame.allocation.AppendableMemory
-
Ensure that at least "bytes" amount of space is available after the cursor.
- RESERVED_FIELD_PREFIX - Static variable in class org.apache.druid.frame.write.FrameWriterUtils
- reset() - Method in class org.apache.druid.frame.segment.columnar.FrameVectorCursor
- reset() - Method in class org.apache.druid.frame.segment.FrameCursor
- reset() - Method in class org.apache.druid.frame.segment.FrameFilteredOffset
- reset() - Method in class org.apache.druid.java.util.common.guava.DelegatingYieldingAccumulator
- reset() - Method in class org.apache.druid.java.util.common.guava.FilteringYieldingAccumulator
- reset() - Method in class org.apache.druid.java.util.common.guava.MappingYieldingAccumulator
- reset() - Method in class org.apache.druid.java.util.common.guava.YieldingAccumulator
- reset() - Method in class org.apache.druid.java.util.common.Stopwatch
- reset() - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
-
Reset all of our aggregators, releasing resources held by them.
- 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 interface org.apache.druid.query.groupby.epinephelinae.column.DimensionIdCodec
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.column.FixedWidthGroupByColumnSelectorStrategy
- reset() - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
-
Reset any internal state held by this selector.
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.DictionaryBuilding
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.PrebuiltDictionary
- 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 class org.apache.druid.query.groupby.epinephelinae.vector.DictionaryBuildingSingleValueStringGroupByVectorColumnSelector
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.DoubleGroupByVectorColumnSelector
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.FloatGroupByVectorColumnSelector
- reset() - Method in interface org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnSelector
-
Reset any internal state held by this selector.
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.LongGroupByVectorColumnSelector
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NilGroupByVectorColumnSelector
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableDoubleGroupByVectorColumnSelector
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableFloatGroupByVectorColumnSelector
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableLongGroupByVectorColumnSelector
- reset() - Method in class org.apache.druid.query.groupby.epinephelinae.vector.SingleValueStringGroupByVectorColumnSelector
- 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.UnnestColumnValueSelectorCursor
- reset() - Method in class org.apache.druid.segment.UnnestDimensionCursor
- 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.
- reset(long) - Method in class org.apache.druid.segment.generator.DataGenerator
-
Reset this generator to start from the begining of the interval with a new seed.
- 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.firstlast.first.GenericFirstAggregateCombiner
- reset(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.firstlast.last.GenericLastAggregateCombiner
- reset(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.LongSumAggregateCombiner
- reset(ColumnValueSelector) - Method in class org.apache.druid.query.aggregation.NullableNumericAggregateCombiner
- resetAggregators(DimValAggregateStore) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
- resetAggregators(Map<Object, Aggregator[]>) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
- resetAggregators(BufferAggregator[]) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
- resetAggregators(TopNColumnAggregatesProcessor) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
- resetPosition() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- resetTestsToDefaultRuntimeInfo() - Static method in class org.apache.druid.utils.JvmUtils
-
Only for testing.
- resetToSize(int) - Method in class org.apache.druid.collections.fastutil.DruidIntList
- resolveHistoricalNullIfNeeded(Integer) - Static method in interface org.apache.druid.indexer.partitions.PartitionsSpec
- resolveHostname() - Static method in exception org.apache.druid.query.QueryException
- RESOURCE_LIMIT_EXCEEDED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- ResourceContainer<ResourceType> - Interface in org.apache.druid.java.util.http.client.pool
- ResourceFactory<K,V> - Interface in org.apache.druid.java.util.http.client.pool
- ResourceHolder<T> - Interface in org.apache.druid.collections
- ResourceLimitExceededException - Exception in org.apache.druid.query
-
Exception indicating that an operation failed because it exceeded some configured resource limit.
- ResourceLimitExceededException(String) - Constructor for exception org.apache.druid.query.ResourceLimitExceededException
- ResourceLimitExceededException(String, String, String, String) - Constructor for exception org.apache.druid.query.ResourceLimitExceededException
- ResourcePool<K,V> - Class in org.apache.druid.java.util.http.client.pool
-
A resource pool based on
LoadingCache
. - ResourcePool(ResourceFactory<K, V>, ResourcePoolConfig, boolean) - Constructor for class org.apache.druid.java.util.http.client.pool.ResourcePool
- ResourcePoolConfig - Class in org.apache.druid.java.util.http.client.pool
- ResourcePoolConfig(int, boolean, long) - Constructor for class org.apache.druid.java.util.http.client.pool.ResourcePoolConfig
-
Deprecated.
- ResourcePoolConfig(int, long) - Constructor for class org.apache.druid.java.util.http.client.pool.ResourcePoolConfig
- ResponseContext - Class in org.apache.druid.query.context
-
The context for storing and passing data between chains of
QueryRunner
s. - ResponseContext() - Constructor for class org.apache.druid.query.context.ResponseContext
- ResponseContext.AbstractKey - Class in org.apache.druid.query.context
-
Abstract key class which provides most functionality except the type-specific merge logic.
- ResponseContext.BooleanKey - Class in org.apache.druid.query.context
-
Boolean valued attribute with the semantics that once the flag is set true, it stays true.
- ResponseContext.CounterKey - Class in org.apache.druid.query.context
-
Long valued attribute that holds the accumulation of values assigned.
- ResponseContext.Key - Interface in org.apache.druid.query.context
-
The base interface of a response context key.
- ResponseContext.Keys - Class in org.apache.druid.query.context
-
Global registry of response context keys.
- ResponseContext.LongKey - Class in org.apache.druid.query.context
-
Long valued attribute that holds the latest value assigned.
- ResponseContext.SerializationResult - Class in org.apache.druid.query.context
-
Serialization result of
ResponseContext
. - ResponseContext.StringKey - Class in org.apache.druid.query.context
-
String valued attribute that holds the latest value assigned.
- ResponseContextDeserializer - Class in org.apache.druid.query.context
-
Deserialize a response context.
- ResponseContextDeserializer() - Constructor for class org.apache.druid.query.context.ResponseContextDeserializer
- restart() - Method in class org.apache.druid.java.util.common.Stopwatch
-
Invokes
reset().start()
on the underlyingStopwatch
. - restore(DataSegment) - Method in interface org.apache.druid.segment.loading.DataSegmentArchiver
-
Perform the restore from an archived segment and return the resulting segment or null if there was no action
- restrictColumns(List<String>) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- restrictColumns(List<String>) - Method in interface org.apache.druid.query.rowsandcols.semantic.RowsAndColumnsDecorator
- result() - Method in class org.apache.druid.frame.processor.manager.AccumulatingProcessorManager
- result() - Method in interface org.apache.druid.frame.processor.manager.ProcessorManager
-
Called after all procesors are done, prior to
ProcessorManager.close()
, to retrieve the result of this computation. - result() - Method in class org.apache.druid.frame.processor.manager.SequenceProcessorManager
- Result<T> - Class in org.apache.druid.query
- Result(DateTime, T) - Constructor for class org.apache.druid.query.Result
- RESULT_FORMAT_COMPACTED_LIST - org.apache.druid.query.scan.ScanQuery.ResultFormat
- RESULT_FORMAT_LIST - org.apache.druid.query.scan.ScanQuery.ResultFormat
- RESULT_FORMAT_VALUE_VECTOR - org.apache.druid.query.scan.ScanQuery.ResultFormat
- resultArraySignature(GroupByQuery) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
- resultArraySignature(WindowOperatorQuery) - Method in class org.apache.druid.query.operator.WindowOperatorQueryQueryToolChest
- resultArraySignature(ScanQuery) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
- resultArraySignature(TimeBoundaryQuery) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
- resultArraySignature(TimeseriesQuery) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
- resultArraySignature(TopNQuery) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
- resultArraySignature(QueryType) - Method in class org.apache.druid.query.QueryToolChest
-
Returns a
RowSignature
for the arrays returned byQueryToolChest.resultsAsArrays(QueryType, org.apache.druid.java.util.common.guava.Sequence<ResultType>)
. - 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<DimensionSpec>) - 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(WindowOperatorQuery, Sequence<RowsAndColumns>) - Method in class org.apache.druid.query.operator.WindowOperatorQueryQueryToolChest
- resultsAsArrays(ScanQuery, Sequence<ScanResultValue>) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
- resultsAsArrays(TimeBoundaryQuery, Sequence<Result<TimeBoundaryResultValue>>) - Method in class org.apache.druid.query.timeboundary.TimeBoundaryQueryQueryToolChest
- 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
- resultsAsArrays(QueryType, Sequence<ResultType>) - Method in class org.apache.druid.query.QueryToolChest
-
Converts a sequence of this query's ResultType into arrays.
- resultsAsFrames(GroupByQuery, Sequence<ResultRow>, MemoryAllocatorFactory, boolean) - Method in class org.apache.druid.query.groupby.GroupByQueryQueryToolChest
-
This returns a single frame containing the results of the group by query.
- resultsAsFrames(ScanQuery, Sequence<ScanResultValue>, MemoryAllocatorFactory, boolean) - Method in class org.apache.druid.query.scan.ScanQueryQueryToolChest
-
This batches the fetched
ScanResultValue
s which have similar signatures and are consecutives. - resultsAsFrames(TimeseriesQuery, Sequence<Result<TimeseriesResultValue>>, MemoryAllocatorFactory, boolean) - Method in class org.apache.druid.query.timeseries.TimeseriesQueryQueryToolChest
-
This returns a single frame containing the results of the timeseries query
- resultsAsFrames(TopNQuery, Sequence<Result<TopNResultValue>>, MemoryAllocatorFactory, boolean) - Method in class org.apache.druid.query.topn.TopNQueryQueryToolChest
-
This returns a single frame containing the rows of the topN query's results
- resultsAsFrames(QueryType, Sequence<ResultType>, MemoryAllocatorFactory, boolean) - Method in class org.apache.druid.query.QueryToolChest
-
Converts a sequence of this query's ResultType into a sequence of
FrameSignaturePair
. - resume(long) - Method in interface org.apache.druid.java.util.http.client.response.HttpResponseHandler.TrafficCop
-
Call this to resume reading after you have suspended it.
- retainAll(Collection<?>) - Method in class org.apache.druid.collections.IntegerSet
- rethrow(Throwable) - Method in class org.apache.druid.java.util.common.io.Closer
-
Stores the given throwable and rethrows it.
- retry(RetryUtils.Task<T>, Predicate<Throwable>, int) - Static method in class org.apache.druid.java.util.common.RetryUtils
- retry(RetryUtils.Task<T>, Predicate<Throwable>, int, int) - Static method in class org.apache.druid.java.util.common.RetryUtils
- retry(RetryUtils.Task<T>, Predicate<Throwable>, int, int, RetryUtils.CleanupAfterFailure, String) - Static method in class org.apache.druid.java.util.common.RetryUtils
-
Retry an operation using fuzzy exponentially increasing backoff.
- retry(RetryUtils.Task<T>, Predicate<Throwable>, RetryUtils.CleanupAfterFailure, int, String) - Static method in class org.apache.druid.java.util.common.RetryUtils
- RetryableException - Exception in org.apache.druid.java.util
-
This Exception class can be use with
RetryUtils
. - RetryableException(Throwable) - Constructor for exception org.apache.druid.java.util.RetryableException
- retryableFailure(Exception) - Static method in class org.apache.druid.common.config.ConfigManager.SetResult
- retryCondition(Predicate<Throwable>) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- retryCopy(ByteSource, ByteSink, Predicate<Throwable>, int) - Static method in class org.apache.druid.java.util.common.StreamUtils
-
Retry copy attempts from input stream to output stream.
- retryCopy(ByteSource, File, Predicate<Throwable>, int) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Copy input byte source to outFile.
- RetryingInputEntity - Class in org.apache.druid.data.input
- RetryingInputEntity() - Constructor for class org.apache.druid.data.input.RetryingInputEntity
- RetryingInputStream<T> - Class in org.apache.druid.data.input.impl
-
This class is responsible for re-opening the underlying input stream for the input object on the given
RetryingInputStream.retryCondition
. - RetryingInputStream(T, ObjectOpenFunction<T>, Predicate<Throwable>, Integer) - Constructor for class org.apache.druid.data.input.impl.RetryingInputStream
- RetryUtils - Class in org.apache.druid.java.util.common
- RetryUtils() - Constructor for class org.apache.druid.java.util.common.RetryUtils
- RetryUtils.CleanupAfterFailure - Interface in org.apache.druid.java.util.common
- RetryUtils.Task<T> - Interface in org.apache.druid.java.util.common
- RETURN_PARTIAL_RESULTS_KEY - Static variable in class org.apache.druid.query.QueryContexts
- returnNull(Indexed<T>) - Static method in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
-
Combine the first two values into a literal null.
- RETURNNULL - org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
- returnObject(T) - Static method in class org.apache.druid.frame.processor.ReturnOrAwait
-
Return a result.
- ReturnOrAwait<T> - Class in org.apache.druid.frame.processor
-
Instances of this class are returned by
FrameProcessor.runIncrementally(it.unimi.dsi.fastutil.ints.IntSet)
, and are used byFrameProcessorExecutor
to manage execution. - returnResource() - Method in interface org.apache.druid.java.util.http.client.pool.ResourceContainer
- ReusableEntry<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
-
A
Grouper.Entry
implementation that is reusable. - ReusableEntry(KeyType, Object[]) - Constructor for class org.apache.druid.query.groupby.epinephelinae.ReusableEntry
- ReverseFunc() - Constructor for class org.apache.druid.math.expr.Function.ReverseFunc
- rewindCursor(int) - Method in class org.apache.druid.frame.allocation.AppendableMemory
-
Rewinds the cursor a certain number of bytes, effectively erasing them.
- REWRITE_JOIN_TO_FILTER_ENABLE_KEY - Static variable in class org.apache.druid.query.QueryContexts
- rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.query.filter.EqualityFilter
- 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.query.filter.NullFilter
- rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.query.filter.RangeFilter
- rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.query.filter.TypedInFilter
- rewriteRequiredColumns(Map<String, String>) - Method in class org.apache.druid.segment.filter.AndFilter
- 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.IsBooleanFilter
- 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.OrFilter
- 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
- rhs - Variable in class org.apache.druid.java.util.common.NonnullPair
- rhs - Variable in class org.apache.druid.java.util.common.Pair
- 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
- RIGHT - org.apache.druid.segment.join.JoinType
- RightFunc() - Constructor for class org.apache.druid.math.expr.Function.RightFunc
- RightTrimExprMacro() - Constructor for class org.apache.druid.query.expression.TrimExprMacro.RightTrimExprMacro
- rint(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Rint() - Constructor for class org.apache.druid.math.expr.Function.Rint
- 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
- RoaringBitmapSerdeFactory - Class in org.apache.druid.segment.data
- RoaringBitmapSerdeFactory(BitmapFactory) - Constructor for class org.apache.druid.segment.data.RoaringBitmapSerdeFactory
- ROLLUP - org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
- ROOT - org.apache.druid.java.util.common.parsers.JSONPathFieldType
- ROOT_GEN_END_PARTITION_ID - Static variable in class org.apache.druid.timeline.partition.PartitionIds
-
End partitionId available for root generation segments.
- ROOT_GEN_START_PARTITION_ID - Static variable in class org.apache.druid.timeline.partition.PartitionIds
-
Start partitionId available for root generation segments.
- Round() - Constructor for class org.apache.druid.math.expr.Function.Round
- ROUNDED_NORMAL - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- Row - Interface in org.apache.druid.data.input
-
A Row of data.
- ROW_BASED - org.apache.druid.frame.FrameType
- ROW_DATA_REGION - Static variable in class org.apache.druid.frame.write.RowBasedFrameWriter
- ROW_MEMORY_COLUMN - Static variable in class org.apache.druid.frame.segment.row.FrameColumnSelectorFactory
-
Name of the virtual column that contains
MemoryRange
for direct access to row memory. - ROW_OFFSET_REGION - Static variable in class org.apache.druid.frame.write.RowBasedFrameWriter
- ROW_SIGNATURE_COLUMN - Static variable in class org.apache.druid.frame.segment.row.FrameColumnSelectorFactory
-
Name of the virtual column that contains the
RowSignature
of frames from thisColumnSelectorFactory
. - ROW_TERMINATOR - Static variable in class org.apache.druid.frame.field.StringFieldWriter
- rowAdapter() - Method in class org.apache.druid.data.input.impl.InputEntityIteratingReader
- rowAdapter() - Method in class org.apache.druid.data.input.impl.TimedShutoffInputSourceReader
- rowAdapter() - Method in interface org.apache.druid.data.input.InputSourceReader
-
Returns an adapter that can be used to read the rows from
InputSourceReader.read()
. - 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 aRowAdapter
for that type of object. - RowBasedColumnSelectorFactory(Supplier<T>, RowIdSupplier, RowAdapter<T>, ColumnInspector, boolean, boolean) - Constructor for class org.apache.druid.segment.RowBasedColumnSelectorFactory
-
Full constructor for
RowBasedCursor
. - RowBasedCursor<RowType> - Class in org.apache.druid.segment
-
A
Cursor
that is based on a stream of objects. - RowBasedCursor(RowWalker<RowType>, RowAdapter<RowType>, Filter, Interval, VirtualColumns, Granularity, boolean, RowSignature) - Constructor for class org.apache.druid.segment.RowBasedCursor
- 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, RowIdSupplier) - Constructor for class org.apache.druid.segment.virtual.RowBasedExpressionColumnValueSelector
- RowBasedFrameRowsAndColumns - Class in org.apache.druid.query.rowsandcols.concrete
- RowBasedFrameRowsAndColumns(Frame, RowSignature) - Constructor for class org.apache.druid.query.rowsandcols.concrete.RowBasedFrameRowsAndColumns
- RowBasedFrameWriter - Class in org.apache.druid.frame.write
-
Write row-based frames: type
FrameType.ROW_BASED
. - RowBasedFrameWriter(RowSignature, List<KeyColumn>, List<FieldWriter>, Supplier<MemoryRange<Memory>>, AppendableMemory, AppendableMemory, AppendableMemory) - Constructor for class org.apache.druid.frame.write.RowBasedFrameWriter
- RowBasedFrameWriterFactory - Class in org.apache.druid.frame.write
- RowBasedFrameWriterFactory(MemoryAllocatorFactory, RowSignature, List<KeyColumn>) - Constructor for class org.apache.druid.frame.write.RowBasedFrameWriterFactory
- RowBasedGrouperHelper - Class in org.apache.druid.query.groupby.epinephelinae
-
This class contains shared code between
GroupByMergingQueryRunner
andGroupByRowProcessor
. - RowBasedGrouperHelper.RowBasedKey - Class in org.apache.druid.query.groupby.epinephelinae
- RowBasedIndexBuilder - Class in org.apache.druid.segment.join.table
-
Utility class for creating
IndexedTable.Index
instances. - RowBasedIndexBuilder(ColumnType) - Constructor for class org.apache.druid.segment.join.table.RowBasedIndexBuilder
- 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
- RowBasedIndexedTable(List<RowType>, RowAdapter<RowType>, RowSignature, Set<String>, String, byte[]) - 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, Sequence<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. - RowBasedStorageAdapter(Sequence<RowType>, RowAdapter<RowType>, RowSignature) - Constructor for class org.apache.druid.segment.RowBasedStorageAdapter
- rowCount - Variable in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- RowFunction - Interface in org.apache.druid.segment.transform
-
Interface for evaluating functions on rows.
- RowIdSupplier - Interface in org.apache.druid.segment
-
Returned by
ColumnSelectorFactory.getRowIdSupplier()
. - 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, long) - Constructor for class org.apache.druid.segment.incremental.RowIngestionMetersTotals
- RowIterator - Interface in org.apache.druid.segment
- RowKey - Class in org.apache.druid.frame.key
-
Represents a specific sorting or hashing key.
- RowKeyComparator - Class in org.apache.druid.frame.key
-
Comparator for
RowKey
instances. - RowKeyComparisonRunLengths - Class in org.apache.druid.frame.key
-
Denotes the ascending-descending run lengths of the fields of the keycolumns that can be compared together.
- RowKeyReader - Class in org.apache.druid.frame.key
-
Embeds the logic to read
RowKey
from a particular signature of row-based frame. - RowMemoryFieldPointer - Class in org.apache.druid.frame.field
-
A
ReadableFieldPointer
that is derived from a row-based frame. - RowMemoryFieldPointer(Memory, ReadableFrameRowPointer, int, int) - Constructor for class org.apache.druid.frame.field.RowMemoryFieldPointer
- rowNumber(Integer) - Method in class org.apache.druid.frame.write.InvalidFieldException.Builder
- rowNumber(Integer) - Method in class org.apache.druid.frame.write.InvalidNullByteException.Builder
- 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
- 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
- RowReader - Class in org.apache.druid.frame.field
-
Class for reading rows in the same format as used by
FrameType.ROW_BASED
. - RowReader(List<FieldReader>) - Constructor for class org.apache.druid.frame.field.RowReader
- Rows - Class in org.apache.druid.data.input
- ROWS - org.apache.druid.query.operator.window.WindowFrame.PeerType
- ROWS_PROCESSED - Static variable in class org.apache.druid.indexer.TaskMetricsUtils
- ROWS_PROCESSED_WITH_ERRORS - Static variable in class org.apache.druid.indexer.TaskMetricsUtils
- ROWS_THROWN_AWAY - Static variable in class org.apache.druid.indexer.TaskMetricsUtils
- ROWS_UNPARSEABLE - Static variable in class org.apache.druid.indexer.TaskMetricsUtils
- RowsAndColumns - Interface in org.apache.druid.query.rowsandcols
-
An interface representing a chunk of RowsAndColumns.
- RowsAndColumnsDecorator - Interface in org.apache.druid.query.rowsandcols.semantic
-
An interface for "decorating" a rowsAndColumns.
- rowsAreArrayList() - Method in class org.apache.druid.query.InlineDataSource
- rowSignature() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
- rowSignature() - Method in class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- 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 - Class in org.apache.druid.segment.column
-
Type signature for a row in a Druid datasource or query result.
- RowSignature.Builder - Class in org.apache.druid.segment.column
- RowSignature.Finalization - Enum in org.apache.druid.segment.column
- rowToObject(IndexedInts, DimensionDictionarySelector) - Static method in interface org.apache.druid.segment.DimensionSelector
-
Converts a particular
IndexedInts
to an Object in a standard way, assuming each element in the IndexedInts is a dictionary ID that can be resolved with the provided selector. - RowWalker<T> - Class in org.apache.druid.segment
-
Used by
RowBasedStorageAdapter
andRowBasedCursor
to walk through rows. - RowWalker(Sequence<T>, RowAdapter<T>) - Constructor for class org.apache.druid.segment.RowWalker
- rpad(String, int, String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Returns the string right-padded with the string pad to a length of len characters.
- RpadFunc() - Constructor for class org.apache.druid.math.expr.Function.RpadFunc
- 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
- RULE_expr - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- RULE_fnArgs - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- RULE_lambda - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- RULE_literalElement - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- RULE_longElement - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- RULE_numericElement - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- RULE_start - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- RULE_stringElement - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- ruleNames - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- ruleNames - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- run() - Method in class org.apache.druid.common.guava.ThreadRenamingRunnable
- run() - Method in class org.apache.druid.frame.processor.SuperSorter
-
Starts sorting.
- run() - Method in interface org.apache.druid.indexer.Jobby
- run(QueryPlus<ResultRow>, ResponseContext) - Method in class org.apache.druid.query.groupby.epinephelinae.GroupByMergingQueryRunner
- run(QueryPlus<Result<SearchResultValue>>, ResponseContext) - Method in class org.apache.druid.query.search.SearchQueryRunner
- run(QueryPlus<T>) - Method in interface org.apache.druid.query.QueryRunner
- 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.FluentQueryRunner
- 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(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>, ResponseContext) - Method in class org.apache.druid.query.ReferenceCountingSegmentQueryRunner
- run(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.ReportTimelineMissingSegmentQueryRunner
- 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(QueryPlus<T>, ResponseContext) - Method in class org.apache.druid.query.UnionQueryRunner
- run(QuerySegmentWalker, ResponseContext) - Method in class org.apache.druid.query.QueryPlus
- 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
- runAgain() - Static method in class org.apache.druid.frame.processor.ReturnOrAwait
-
Wait for nothing; that is: run again as soon as possible.
- runAllFully(ProcessorManager<T, R>, int, Bouncer, String) - Method in class org.apache.druid.frame.processor.FrameProcessorExecutor
-
Runs a sequence of processors and returns a future that resolves when execution is complete.
- RunAllFullyWidget<T,ResultType> - Class in org.apache.druid.frame.processor
- runFully(FrameProcessor<T>, String) - Method in class org.apache.druid.frame.processor.FrameProcessorExecutor
-
Runs a processor until it is done, and returns a future that resolves when execution is complete.
- runIncrementally(IntSet) - Method in class org.apache.druid.frame.processor.FrameChannelBatcher
- runIncrementally(IntSet) - Method in class org.apache.druid.frame.processor.FrameChannelHashPartitioner
- runIncrementally(IntSet) - Method in class org.apache.druid.frame.processor.FrameChannelMerger
- runIncrementally(IntSet) - Method in class org.apache.druid.frame.processor.FrameChannelMixer
- runIncrementally(IntSet) - Method in interface org.apache.druid.frame.processor.FrameProcessor
-
Runs some of the algorithm, without blocking, and either returns a value or a set of input channels to wait for.
- RunLengthEntry - Class in org.apache.druid.frame.key
-
Information about a continguous run of keys, that has the same sorting order
- Runnables - Class in org.apache.druid.utils
- Runnables() - Constructor for class org.apache.druid.utils.Runnables
- runnerIntervalMappingIterator() - Method in class org.apache.druid.query.SinkQueryRunners
- RunnerTaskState - Enum in org.apache.druid.indexer
-
This includes the state of a task in the task runner not covered by
TaskState
, this state is not stored in database - running(String) - Static method in class org.apache.druid.indexer.TaskStatus
- RUNNING - org.apache.druid.indexer.RunnerTaskState
- RUNNING - org.apache.druid.indexer.TaskState
- RUNTIME_FAILURE - org.apache.druid.error.DruidException.Category
-
Indicates a server-side failure of some sort at runtime
- RuntimeInfo - Class in org.apache.druid.utils
- RuntimeInfo() - Constructor for class org.apache.druid.utils.RuntimeInfo
- 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
- safeAccumulateThreadCpuTime(AtomicLong, Supplier<T>) - Static method in class org.apache.druid.utils.JvmUtils
-
Executes and returns the value of
function
. - safeBuild(QueryRunner<T>, QueryToolChest<T, ? extends Query<T>>, ServiceEmitter, AtomicLong, boolean) - Static method in class org.apache.druid.query.CPUTimeMetricQueryRunner
- SafeDivide() - Constructor for class org.apache.druid.math.expr.Function.SafeDivide
- safeGetThreadCpuTime() - Static method in class org.apache.druid.utils.JvmUtils
- safeObjectClassGetName(Object) - Static method in class org.apache.druid.java.util.common.collect.Utils
- safeUpperLimitOfStringSize() - Method in class org.apache.druid.timeline.SegmentId
- SafeWritableBase - Class in org.apache.druid.segment.data
- SafeWritableBase(ByteBuffer) - Constructor for class org.apache.druid.segment.data.SafeWritableBase
- SafeWritableBuffer - Class in org.apache.druid.segment.data
-
Safety first! Don't trust something whose contents you locations to read and write stuff to, but need a
Buffer
orWritableBuffer
? use this! - SafeWritableBuffer(ByteBuffer) - Constructor for class org.apache.druid.segment.data.SafeWritableBuffer
- SafeWritableMemory - Class in org.apache.druid.segment.data
-
Safety first! Don't trust something whose contents you locations to read and write stuff to, but need a
Memory
orWritableMemory
? use this! - SafeWritableMemory(ByteBuffer) - Constructor for class org.apache.druid.segment.data.SafeWritableMemory
- sample() - Method in class org.apache.druid.data.input.impl.InputEntityIteratingReader
- sample() - Method in class org.apache.druid.data.input.impl.TimedShutoffInputSourceReader
- sample() - Method in interface org.apache.druid.data.input.InputEntityReader
- sample() - Method in interface org.apache.druid.data.input.InputSourceReader
- sample() - Method in class org.apache.druid.data.input.IntermediateRowParsingReader
- 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
- SanitizableException - Interface in org.apache.druid.common.exception
- sanitize(Function<String, String>) - Method in exception org.apache.druid.query.QueryException
- sanitize(Function<String, String>) - Method in interface org.apache.druid.common.exception.SanitizableException
-
Apply the function for transforming the error message then return new Exception with sanitized fields and transformed message.
- sanitize(Function<String, String>) - Method in exception org.apache.druid.java.util.common.ISE
- sanitize(Function<String, String>) - Method in exception org.apache.druid.java.util.common.UOE
- ScalarDoubleColumn - Class in org.apache.druid.segment.nested
- ScalarDoubleColumn(FixedIndexed<Double>, ColumnarDoubles, ImmutableBitmap) - Constructor for class org.apache.druid.segment.nested.ScalarDoubleColumn
- ScalarDoubleColumnAndIndexSupplier - Class in org.apache.druid.segment.nested
- ScalarDoubleColumnSerializer - Class in org.apache.druid.segment.nested
-
Serializer for a
ScalarDoubleColumn
- ScalarDoubleColumnSerializer(String, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.nested.ScalarDoubleColumnSerializer
- ScalarDoubleFieldColumnWriter - Class in org.apache.druid.segment.nested
-
Nested field writer for double type columns of
NestedDataColumnSerializer
. - ScalarDoubleFieldColumnWriter(String, String, SegmentWriteOutMedium, IndexSpec, DictionaryIdLookup) - Constructor for class org.apache.druid.segment.nested.ScalarDoubleFieldColumnWriter
- ScalarInArrayFunction() - Constructor for class org.apache.druid.math.expr.Function.ScalarInArrayFunction
- ScalarLongColumn - Class in org.apache.druid.segment.nested
- ScalarLongColumn(FixedIndexed<Long>, ColumnarLongs, ImmutableBitmap) - Constructor for class org.apache.druid.segment.nested.ScalarLongColumn
- ScalarLongColumnAndIndexSupplier - Class in org.apache.druid.segment.nested
- ScalarLongColumnSerializer - Class in org.apache.druid.segment.nested
-
Serializer for a
ScalarLongColumn
- ScalarLongColumnSerializer(String, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.nested.ScalarLongColumnSerializer
- ScalarLongFieldColumnWriter - Class in org.apache.druid.segment.nested
-
Nested field writer for long type columns of
NestedDataColumnSerializer
. - ScalarLongFieldColumnWriter(String, String, SegmentWriteOutMedium, IndexSpec, DictionaryIdLookup) - Constructor for class org.apache.druid.segment.nested.ScalarLongFieldColumnWriter
- ScalarNestedCommonFormatColumnSerializer<T> - Class in org.apache.druid.segment.nested
- ScalarNestedCommonFormatColumnSerializer(String, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- ScalarStringColumnAndIndexSupplier - Class in org.apache.druid.segment.nested
- ScalarStringColumnSerializer - Class in org.apache.druid.segment.nested
-
Serializer for a string
NestedCommonFormatColumn
that can be read withStringUtf8DictionaryEncodedColumn
. - ScalarStringColumnSerializer(String, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.nested.ScalarStringColumnSerializer
- ScalarStringFieldColumnWriter - Class in org.apache.druid.segment.nested
-
Nested field writer for string type columns of
NestedDataColumnSerializer
- ScalarStringFieldColumnWriter(String, String, SegmentWriteOutMedium, IndexSpec, DictionaryIdLookup) - Constructor for class org.apache.druid.segment.nested.ScalarStringFieldColumnWriter
- scalb(Expr.VectorInputBindingInspector, Expr, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Scalb() - Constructor for class org.apache.druid.math.expr.Function.Scalb
- SCAN - Static variable in interface org.apache.druid.query.Query
- scanAndAggregate(DimensionSelectorType, MetricSelectorType, BufferAggregatorType, int, HistoricalCursor, int[], ByteBuffer) - Method in interface org.apache.druid.query.topn.Historical1AggPooledTopNScanner
- scanAndAggregate(PooledTopNAlgorithm.PooledTopNParams, int[], BufferAggregator[]) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
- scanAndAggregate(TopNParams, int[], Map<Object, Aggregator[]>) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
- scanAndAggregate(TopNParams, Aggregator[][], TopNColumnAggregatesProcessor) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
- scanAndAggregate(TopNQuery, DimensionSelector, Cursor, Aggregator[][]) - Method in class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
- scanAndAggregate(TopNQuery, Selector, Cursor, Aggregator[][]) - Method in class org.apache.druid.query.topn.types.NullableNumericTopNColumnAggregatesProcessor
- scanAndAggregate(TopNQuery, ValueSelectorType, Cursor, Aggregator[][]) - Method in interface org.apache.druid.query.topn.types.TopNColumnAggregatesProcessor
-
Used by
HeapBasedTopNAlgorithm
. - 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(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(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(Parameters, DimValSelector, DimValAggregateStore) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
-
Returns the number of processed rows (i.
- ScanOperator - Class in org.apache.druid.query.operator
-
A scan operator is really just a way to push down various things that can be lazily applied when data needs to actually be read.
- ScanOperator(Operator, List<String>, VirtualColumns, Interval, Filter, List<ColumnWithDirection>, OffsetLimit) - Constructor for class org.apache.druid.query.operator.ScanOperator
- ScanOperatorFactory - Class in org.apache.druid.query.operator
- ScanOperatorFactory(Interval, DimFilter, OffsetLimit, List<String>, VirtualColumns, List<ColumnWithDirection>) - Constructor for class org.apache.druid.query.operator.ScanOperatorFactory
- ScanQuery - Class in org.apache.druid.query.scan
- ScanQuery(DataSource, QuerySegmentSpec, VirtualColumns, ScanQuery.ResultFormat, int, long, long, ScanQuery.Order, List<ScanQuery.OrderBy>, DimFilter, List<String>, Boolean, Map<String, Object>, List<ColumnType>) - Constructor for class org.apache.druid.query.scan.ScanQuery
- ScanQuery.Order - Enum in org.apache.druid.query.scan
- ScanQuery.OrderBy - Class 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.
- 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
- ScanResultValue(String, List<String>, Object, RowSignature) - Constructor for class org.apache.druid.query.scan.ScanResultValue
- ScanResultValueFramesIterable - Class in org.apache.druid.query.scan
-
Returns a thread-unsafe iterable, that converts a sequence of
ScanResultValue
to an iterable ofFrameSignaturePair
. - ScanResultValueFramesIterable(Sequence<ScanResultValue>, MemoryAllocatorFactory, boolean, RowSignature, Function<RowSignature, Function<?, Object[]>>) - Constructor for class org.apache.druid.query.scan.ScanResultValueFramesIterable
- ScanResultValueIterator - Class in org.apache.druid.query.scan
-
Iterates over the scan result sequence and provides an interface to clean up the resources (if any) to close the underlying sequence.
- ScanResultValueIterator(Sequence<ScanResultValue>) - Constructor for class org.apache.druid.query.scan.ScanResultValueIterator
- 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
- scheduleAtFixedRate(ScheduledExecutorService, Duration, Callable<ScheduledExecutors.Signal>) - Static method in class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
- scheduleAtFixedRate(ScheduledExecutorService, Duration, Duration, Runnable) - Static method in class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
-
Run runnable once every period, after the given initial delay.
- scheduleAtFixedRate(ScheduledExecutorService, Duration, Duration, Callable<ScheduledExecutors.Signal>) - Static method in class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
- ScheduledExecutorFactory - Interface in org.apache.druid.java.util.common.concurrent
- ScheduledExecutors - Class in org.apache.druid.java.util.common.concurrent
- ScheduledExecutors() - Constructor for class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
- ScheduledExecutors.Signal - Enum in org.apache.druid.java.util.common.concurrent
- scheduledSingleThreaded(String) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- scheduledSingleThreaded(String, Integer) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- scheduleWithFixedDelay(ScheduledExecutorService, Duration, Callable<ScheduledExecutors.Signal>) - Static method in class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
-
Run callable repeatedly with the given delay between calls, after the given initial delay, until it returns Signal.STOP.
- scheduleWithFixedDelay(ScheduledExecutorService, Duration, Duration, Runnable) - Static method in class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
-
Run runnable repeatedly with the given delay between calls, after the given initial delay.
- scheduleWithFixedDelay(ScheduledExecutorService, Duration, Duration, Callable<ScheduledExecutors.Signal>) - Static method in class org.apache.druid.java.util.common.concurrent.ScheduledExecutors
-
Run callable repeatedly with the given delay between calls, until it returns Signal.STOP.
- SCHEMA_MAP - Static variable in class org.apache.druid.segment.generator.GeneratorBasicSchemas
- SchemaPayload - Class in org.apache.druid.segment
-
Representation of schema payload, includes information like RowSignature and aggregator factories.
- SchemaPayload(RowSignature) - Constructor for class org.apache.druid.segment.SchemaPayload
- SchemaPayload(RowSignature, Map<String, AggregatorFactory>) - Constructor for class org.apache.druid.segment.SchemaPayload
- SchemaPayloadPlus - Class in org.apache.druid.segment
-
Wrapper over
SchemaPayload
to includenumRows
information. - SchemaPayloadPlus(SchemaPayload, Long) - Constructor for class org.apache.druid.segment.SchemaPayloadPlus
- SCHEME - Static variable in class org.apache.druid.initialization.TombstoneDataStorageModule
- scope(Key<T>, Provider<T>) - Method in class org.apache.druid.guice.LifecycleScope
- search(ImmutableNode<TCoordinateArray>, Bound<TCoordinateArray, TPoint>) - Method in class org.apache.druid.collections.spatial.search.GutmanSearchStrategy
- search(ImmutableNode<TCoordinateArray>, Bound<TCoordinateArray, TPoint>) - Method in interface org.apache.druid.collections.spatial.search.SearchStrategy
- search(Bound) - Method in interface org.apache.druid.collections.spatial.BaseImmutableRTee
- search(Bound) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
- search(SearchStrategy, Bound) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
- 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
- SearchableVersionedDataFinder<DataDescriptor> - Interface in org.apache.druid.data
-
A class which implements SearchableVersionedDataFinder can find a DataDescriptor which describes the most up to date version of data given a base descriptor and a matching pattern.
- 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) - Constructor for class org.apache.druid.query.search.SearchHit
- SearchHit(String, String, Integer) - 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>, VirtualColumns, 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
- SearchQueryDimFilter - Class in org.apache.druid.query.filter
- SearchQueryDimFilter(String, SearchQuerySpec, ExtractionFn) - Constructor for class org.apache.druid.query.filter.SearchQueryDimFilter
- SearchQueryDimFilter(String, SearchQuerySpec, ExtractionFn, FilterTuning) - 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 - Class in org.apache.druid.query.search
- SearchStrategy<TCoordinateArray,TPoint extends ImmutableNode<TCoordinateArray>> - Interface in org.apache.druid.collections.spatial.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
- second - Variable in class org.apache.druid.java.util.common.Triple
- SECOND - org.apache.druid.java.util.common.granularity.GranularityType
- SECOND - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- SECOND - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- SECONDARY_PARTITION_PRUNING_KEY - Static variable in class org.apache.druid.query.QueryContexts
- SecondaryModule(ExtensionsLoader) - Constructor for class org.apache.druid.guice.ExtensionsModule.SecondaryModule
- SecondaryPartitionType - Enum in org.apache.druid.indexer.partitions
-
In Druid, ingested data are primarily partitioned based on time range (@link GranularitySpec#getSegmentGranularity), and then secondly partitioned based on the given
PartitionsSpec
. - seek(int) - Method in interface org.apache.druid.segment.DictionaryEncodedColumnMerger.IndexSeeker
- seek(int) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger.IndexSeekerWithConversion
- seek(int) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger.IndexSeekerWithoutConversion
- seekBlock(int) - Method in class org.apache.druid.segment.data.CompressedBlockReader
-
Swap the current data in
CompressedBlockReader.decompressedDataBuffer
to the specified block - segment - Variable in class org.apache.druid.query.search.SearchQueryExecutor
- 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 - Interface in org.apache.druid.segment
-
The difference between this class and
DataSegment
is thatDataSegment
contains the segment metadata only, while this class represents the actual body of segment data, queryable. - SEGMENT_AVAILABILITY_WAIT - org.apache.druid.indexer.IngestionState
- SEGMENT_METADATA - Static variable in interface org.apache.druid.query.Query
- SegmentAnalysis - Class in org.apache.druid.query.metadata.metadata
- SegmentAnalysis(String, List<Interval>, LinkedHashMap<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
- SegmentDescriptor - Class in org.apache.druid.query
- SegmentDescriptor(Interval, String, int) - Constructor for class org.apache.druid.query.SegmentDescriptor
- segmentForTombstone(DataSegment) - Static method in class org.apache.druid.segment.loading.TombstoneSegmentizerFactory
- SegmentId - Class in org.apache.druid.timeline
-
Identifier of
DataSegment
. - 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
- SegmentLazyLoadFailCallback - Interface in org.apache.druid.segment
- SegmentLoadingException - Exception in org.apache.druid.segment.loading
- SegmentLoadingException(String, Object...) - Constructor for exception org.apache.druid.segment.loading.SegmentLoadingException
- SegmentLoadingException(Throwable, String, Object...) - Constructor for exception org.apache.druid.segment.loading.SegmentLoadingException
- SegmentMetadata - Class in org.apache.druid.segment
-
Encapsulates segment level information like numRows, schema fingerprint.
- SegmentMetadata(Long, String) - Constructor for class org.apache.druid.segment.SegmentMetadata
- SegmentMetadataEvent - Class in org.apache.druid.java.util.emitter.service
-
The event that gets generated whenever a segment is committed
- SegmentMetadataEvent(String, DateTime, DateTime, DateTime, String, boolean) - Constructor for class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- SegmentMetadataQuery - Class in org.apache.druid.query.metadata.metadata
- SegmentMetadataQuery(DataSource, QuerySegmentSpec, ColumnIncluderator, Boolean, Map<String, Object>, EnumSet<SegmentMetadataQuery.AnalysisType>, Boolean, Boolean, AggregatorMergeStrategy) - 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() - Constructor for class org.apache.druid.query.metadata.SegmentMetadataQueryConfig
- SegmentMetadataQueryConfig(String) - 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 asReferenceCountingSegment
where the reference is the segment itself, andHashJoinSegment
which wraps aReferenceCountingSegment
and also includes the associated list ofJoinableClause
- SegmentSchemaMapping - Class in org.apache.druid.segment
-
Compact representation of segment schema for multiple segments.
- SegmentSchemaMapping(int) - Constructor for class org.apache.druid.segment.SegmentSchemaMapping
- SegmentSchemaMapping(Map<String, SegmentMetadata>, Map<String, SchemaPayload>, int) - Constructor for class org.apache.druid.segment.SegmentSchemaMapping
- SegmentsSplitHintSpec - Class in org.apache.druid.data.input
-
SplitHintSpec
for IngestSegmentFirehoseFactory and DruidInputSource. - SegmentsSplitHintSpec(HumanReadableBytes, Integer) - Constructor for class org.apache.druid.data.input.SegmentsSplitHintSpec
- SegmentStatusInCluster - Class in org.apache.druid.timeline
-
This class represents the current state of a segment in the cluster and encapsulates the following: the
DataSegment
object overshadowed status of the segment replication factor of the segment number of rows in the segment if the segment is realtime
Objects of this class are used to sync the state of segments from the Coordinator to different services, typically the Broker. - SegmentStatusInCluster(boolean, Integer, Long, boolean) - Constructor for class org.apache.druid.timeline.SegmentStatusInCluster
- SegmentStatusInCluster(DataSegment, boolean, Integer, Long, boolean) - Constructor for class org.apache.druid.timeline.SegmentStatusInCluster
- SegmentTimeline - Class in org.apache.druid.timeline
-
VersionedIntervalTimeline
forDataSegment
objects. - SegmentTimeline() - Constructor for class org.apache.druid.timeline.SegmentTimeline
- SegmentToRowsAndColumnsOperator - Class in org.apache.druid.query.operator
- SegmentToRowsAndColumnsOperator(Segment) - Constructor for class org.apache.druid.query.operator.SegmentToRowsAndColumnsOperator
- SegmentUtils - Class in org.apache.druid.segment
-
Utility methods useful for implementing deep storage extensions.
- 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.DictionaryEncodedColumnMerger
- segmentWriteOutMedium - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- segmentWriteOutMedium - Variable in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- 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 callingSegmentWriteOutMedium.makeWriteOutBytes()
on the SegmentWriteOutMedium instance), that are used during new Druid segment creation, and other resources (seeSegmentWriteOutMedium.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
- SELECTION_SIZE - Static variable in interface org.apache.druid.segment.column.ColumnConfig
-
Use range indexes if dictionary range is same size or smaller than selection size
- SelectionPredicate - Interface in org.apache.druid.query.aggregation.firstlast
-
Differentiating factor between the first and the last aggregator.
- selector - Variable in class org.apache.druid.query.filter.vector.ArrayVectorValueMatcher
- selector - Variable in class org.apache.druid.query.filter.vector.ObjectVectorValueMatcher
- selector - Variable in class org.apache.druid.query.filter.vector.StringObjectVectorValueMatcher
- 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
- Selector(Memory, ReadableFieldPointer, byte) - Constructor for class org.apache.druid.frame.field.NumericFieldReader.Selector
- SelectorDimFilter - Class in org.apache.druid.query.filter
-
Recommended to use
EqualityFilter
orNullFilter
instead - SelectorDimFilter(String, String, ExtractionFn) - Constructor for class org.apache.druid.query.filter.SelectorDimFilter
- SelectorDimFilter(String, String, ExtractionFn, FilterTuning) - 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 theSelectorFilter.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, Class) - Static method in class org.apache.druid.query.aggregation.firstlast.FirstLastUtils
-
Returns whether a given value selector *might* contain object assignable from pairClass (SerializablePairLong*).
- 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.
- selectRandom(IntSet) - Static method in class org.apache.druid.frame.processor.FrameProcessors
-
Selects a random element from a set of ints.
- Self - Annotation Type in org.apache.druid.guice.annotations
-
Binding annotation for org.apache.druid.server.DruidNode.
- SemanticCreator - Annotation Type in org.apache.druid.query.rowsandcols
-
Annotation used to indicate that the method is used as a creator for a semantic interface.
- sempred(RuleContext, int, int) - Method in class org.apache.druid.math.expr.antlr.ExprParser
- separatorLength() - Method in enum org.apache.druid.java.util.emitter.core.BatchingStrategy
- Sequence<T> - Interface in org.apache.druid.java.util.common.guava
-
A Sequence represents an iterable sequence of elements.
- SEQUENCE_BIT - Static variable in class org.apache.druid.extendedset.intset.ConciseSetUtils
-
Sequence bit
- SequenceInputStreamResponseHandler - Class in org.apache.druid.java.util.http.client.response
-
A HTTP response handler which uses sequence input streams to create a final InputStream.
- SequenceInputStreamResponseHandler() - Constructor for class org.apache.druid.java.util.http.client.response.SequenceInputStreamResponseHandler
- SequenceOperator - Class in org.apache.druid.query.operator
- SequenceOperator(Sequence<RowsAndColumns>) - Constructor for class org.apache.druid.query.operator.SequenceOperator
- SequenceProcessorManager<T,P extends FrameProcessor<T>> - Class in org.apache.druid.frame.processor.manager
-
Processor manager based on a
Sequence
. - Sequences - Class in org.apache.druid.java.util.common.guava
- Sequences() - Constructor for class org.apache.druid.java.util.common.guava.Sequences
- SequenceWrapper - Class in org.apache.druid.java.util.common.guava
- SequenceWrapper() - Constructor for class org.apache.druid.java.util.common.guava.SequenceWrapper
- SEQUENTIAL - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- SequentialDistribution - Class in org.apache.druid.segment.generator
- SequentialDistribution(Integer, Integer, List<Object>) - Constructor for class org.apache.druid.segment.generator.SequentialDistribution
- sequentialStreamFrom(Iterable<T>) - Static method in class org.apache.druid.utils.Streams
- sequentialStreamFrom(Iterator<T>) - Static method in class org.apache.druid.utils.Streams
- SerializablePair<T1,T2> - Class in org.apache.druid.collections
- SerializablePair(T1, T2) - Constructor for class org.apache.druid.collections.SerializablePair
- SerializablePairLongDouble - Class in org.apache.druid.query.aggregation
- SerializablePairLongDouble(Long, Double) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongDouble
- SerializablePairLongDoubleBufferStore - Class in org.apache.druid.query.aggregation
- SerializablePairLongDoubleBufferStore(SerializedStorage<SerializablePairLongDouble>) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongDoubleBufferStore
- SerializablePairLongDoubleColumnHeader - Class in org.apache.druid.query.aggregation
- SerializablePairLongDoubleColumnSerializer - Class in org.apache.druid.query.aggregation
- SerializablePairLongDoubleColumnSerializer(SegmentWriteOutMedium, ByteBufferProvider) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongDoubleColumnSerializer
- SerializablePairLongDoubleComplexColumn - Class in org.apache.druid.query.aggregation
- SerializablePairLongDoubleComplexColumn(CellReader, AbstractSerializablePairLongObjectDeltaEncodedStagedSerde<?>, Closer, int) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexColumn
- SerializablePairLongDoubleComplexColumn.Builder - Class in org.apache.druid.query.aggregation
- SerializablePairLongDoubleComplexMetricSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongDoubleComplexMetricSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexMetricSerde
- SerializablePairLongDoubleDeltaEncodedStagedSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongDoubleDeltaEncodedStagedSerde(long, boolean) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongDoubleDeltaEncodedStagedSerde
- SerializablePairLongDoubleSimpleStagedSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongDoubleSimpleStagedSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongDoubleSimpleStagedSerde
- SerializablePairLongFloat - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloat(Long, Float) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongFloat
- SerializablePairLongFloatBufferStore - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloatBufferStore(SerializedStorage<SerializablePairLongFloat>) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongFloatBufferStore
- SerializablePairLongFloatColumnHeader - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloatColumnSerializer - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloatColumnSerializer(SegmentWriteOutMedium, ByteBufferProvider) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongFloatColumnSerializer
- SerializablePairLongFloatComplexColumn - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloatComplexColumn(CellReader, AbstractSerializablePairLongObjectDeltaEncodedStagedSerde<?>, Closer, int) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn
- SerializablePairLongFloatComplexColumn.Builder - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloatComplexMetricSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloatComplexMetricSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexMetricSerde
- SerializablePairLongFloatDeltaEncodedStagedSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloatDeltaEncodedStagedSerde(long, boolean) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongFloatDeltaEncodedStagedSerde
- SerializablePairLongFloatSimpleStagedSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongFloatSimpleStagedSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongFloatSimpleStagedSerde
- SerializablePairLongLong - Class in org.apache.druid.query.aggregation
- SerializablePairLongLong(Long, Long) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongLong
- SerializablePairLongLongBufferStore - Class in org.apache.druid.query.aggregation
- SerializablePairLongLongBufferStore(SerializedStorage<SerializablePairLongLong>) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongLongBufferStore
- SerializablePairLongLongColumnHeader - Class in org.apache.druid.query.aggregation
- SerializablePairLongLongColumnSerializer - Class in org.apache.druid.query.aggregation
- SerializablePairLongLongColumnSerializer(SegmentWriteOutMedium, ByteBufferProvider) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongLongColumnSerializer
- SerializablePairLongLongComplexColumn - Class in org.apache.druid.query.aggregation
- SerializablePairLongLongComplexColumn(CellReader, AbstractSerializablePairLongObjectDeltaEncodedStagedSerde<?>, Closer, int) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn
- SerializablePairLongLongComplexColumn.Builder - Class in org.apache.druid.query.aggregation
- SerializablePairLongLongComplexMetricSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongLongComplexMetricSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongLongComplexMetricSerde
- SerializablePairLongLongDeltaEncodedStagedSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongLongDeltaEncodedStagedSerde(long, boolean) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongLongDeltaEncodedStagedSerde
- SerializablePairLongLongSimpleStagedSerde - Class in org.apache.druid.query.aggregation
- SerializablePairLongLongSimpleStagedSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongLongSimpleStagedSerde
- SerializablePairLongString - Class in org.apache.druid.query.aggregation
- SerializablePairLongString(Long, String) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongString
- SerializablePairLongStringBufferStore - Class in org.apache.druid.query.aggregation
- SerializablePairLongStringBufferStore(SerializedStorage<SerializablePairLongString>) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringBufferStore
- SerializablePairLongStringColumnHeader - Class in org.apache.druid.query.aggregation
- SerializablePairLongStringColumnHeader(int, boolean, long) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringColumnHeader
- SerializablePairLongStringColumnSerializer - Class in org.apache.druid.query.aggregation
-
valid call sequence
- SerializablePairLongStringColumnSerializer(SegmentWriteOutMedium, ByteBufferProvider) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringColumnSerializer
- SerializablePairLongStringComplexColumn - Class in org.apache.druid.query.aggregation
- SerializablePairLongStringComplexColumn(CellReader, SerializablePairLongStringDeltaEncodedStagedSerde, Closer, int) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn
- SerializablePairLongStringComplexColumn.Builder - Class in org.apache.druid.query.aggregation
- SerializablePairLongStringComplexMetricSerde - Class in org.apache.druid.query.aggregation
-
The SerializablePairLongStringSerde serializes a Long-String pair (SerializablePairLongString).
- SerializablePairLongStringComplexMetricSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringComplexMetricSerde
- SerializablePairLongStringComplexMetricSerde(boolean) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringComplexMetricSerde
- SerializablePairLongStringDeltaEncodedStagedSerde - Class in org.apache.druid.query.aggregation
-
serializes a Long/String pair in the context of a column/segment.
- SerializablePairLongStringDeltaEncodedStagedSerde(long, boolean) - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringDeltaEncodedStagedSerde
- SerializablePairLongStringSimpleStagedSerde - Class in org.apache.druid.query.aggregation
-
serializes a Long/String pair as Long:Integer:bytes
- SerializablePairLongStringSimpleStagedSerde() - Constructor for class org.apache.druid.query.aggregation.SerializablePairLongStringSimpleStagedSerde
- SerializationResult(String, String) - Constructor for class org.apache.druid.query.context.ResponseContext.SerializationResult
- serialize(long) - Method in class org.apache.druid.segment.serde.cell.IntSerializer
- serialize(long) - Method in class org.apache.druid.segment.serde.cell.LongSerializer
- serialize(long) - Method in interface org.apache.druid.segment.serde.cell.NumberSerializer
- serialize(JsonGenerator, SerializerProvider) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- serialize(ByteBuffer) - Method in class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
- serialize(ByteBuffer) - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
- serialize(ByteBuffer, int, ExpressionType, ExprEval<?>, int) - Static method in class org.apache.druid.math.expr.ExprEval
-
Write an expression result to a bytebuffer, throwing an
ISE
if the data exceeds a maximum size. - serialize(List<String>, JsonGenerator, SerializerProvider) - Method in class org.apache.druid.jackson.CommaListJoinSerializer
- serialize(HumanReadableBytes, JsonGenerator, SerializerProvider) - Method in class org.apache.druid.java.util.common.HumanReadableBytesSerializer
- serialize(EventMap, JsonGenerator, SerializerProvider) - Method in class org.apache.druid.java.util.emitter.core.EventMapSerializer
- serialize(DoubleMeanHolder, JsonGenerator, SerializerProvider) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder.Serializer
- serialize(FrameBasedInlineDataSource, JsonGenerator, SerializerProvider) - Method in class org.apache.druid.query.FrameBasedInlineDataSourceSerializer
- 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<?>) - Method in class org.apache.druid.segment.LongColumnSerializer
- serialize(ColumnValueSelector<?>) - Method in class org.apache.druid.segment.LongColumnSerializerV2
- serialize(ColumnValueSelector<? extends StructuredData>) - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- serialize(ColumnValueSelector<? extends StructuredData>) - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- serialize(ColumnValueSelector<? extends StructuredData>) - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- serialize(ColumnValueSelector<? extends StructuredData>) - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- serialize(ColumnValueSelector<? extends T>) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnSerializer
- serialize(ColumnValueSelector<? extends T>) - Method in interface org.apache.druid.segment.GenericColumnSerializer
- 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
- serialize(StructuredData, JsonGenerator, SerializerProvider) - Method in class org.apache.druid.segment.nested.StructuredDataJsonSerializer
- serialize(T) - Method in interface org.apache.druid.common.config.ConfigSerde
- serialize(T) - Method in interface org.apache.druid.segment.serde.cell.StagedSerde
-
Default implementation for when a byte[] is desired.
- SERIALIZE_DATE_TIME_AS_LONG_INNER_KEY - Static variable in class org.apache.druid.query.QueryContexts
- SERIALIZE_DATE_TIME_AS_LONG_KEY - Static variable in class org.apache.druid.query.QueryContexts
- serialized() - Method in class org.apache.druid.audit.AuditEntry.Payload
- serializeDelayed(SerializablePairLongString) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringDeltaEncodedStagedSerde
- serializeDelayed(SerializablePairLongString) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringSimpleStagedSerde
- serializeDelayed(T) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectDeltaEncodedStagedSerde
- serializeDelayed(T) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectSimpleStagedSerde
- serializeDelayed(T) - Method in interface org.apache.druid.segment.serde.cell.StagedSerde
-
Useful method when some computation is necessary to prepare for serialization without actually writing out all the bytes in order to determine the serialized size.
- serializeDictionaries(Iterable<String>, Iterable<Long>, Iterable<Double>) - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- serializeDictionaries(Iterable<String>, Iterable<Long>, Iterable<Double>, Iterable<int[]>) - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- serializeDictionaries(Iterable<String>, Iterable<Long>, Iterable<Double>, Iterable<int[]>) - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- serializeDictionaries(Iterable<String>, Iterable<Long>, Iterable<Double>, Iterable<int[]>) - Method in class org.apache.druid.segment.nested.ScalarDoubleColumnSerializer
- serializeDictionaries(Iterable<String>, Iterable<Long>, Iterable<Double>, Iterable<int[]>) - Method in class org.apache.druid.segment.nested.ScalarLongColumnSerializer
- serializeDictionaries(Iterable<String>, Iterable<Long>, Iterable<Double>, Iterable<int[]>) - Method in class org.apache.druid.segment.nested.ScalarStringColumnSerializer
- serializeDictionaries(Iterable<String>, Iterable<Long>, Iterable<Double>, Iterable<int[]>) - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- serializedPayload(String) - Method in class org.apache.druid.audit.AuditEntry.Builder
- SerializedStorage<T> - Class in org.apache.druid.query.aggregation
-
simple utility class useful for when multiple passes of input are needed for encoding (e.g.
- SerializedStorage(WriteOutBytes, StagedSerde<T>) - Constructor for class org.apache.druid.query.aggregation.SerializedStorage
- serializeFields(SortedMap<String, FieldTypeInfo.MutableTypeSet>) - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- serializeFields(SortedMap<String, FieldTypeInfo.MutableTypeSet>) - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- serializeFields(SortedMap<String, FieldTypeInfo.MutableTypeSet>) - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- serializeGroupKey(ObjectMapper, List<Object>) - Static method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
-
Serializes a group key into a byte array.
- 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() - Static method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
- serializerBuilder() - Static method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde
- serializerBuilder() - Static method in class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2
- serializerBuilder() - Static method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerde
- serializerBuilder() - Static method in class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2
- serializerBuilder() - Static method in class org.apache.druid.segment.serde.LongNumericColumnPartSerde
- serializerBuilder() - Static method in class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2
- serializerBuilder() - Static method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.ComplexColumnPartSerde.SerializerBuilder
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.DoubleNumericColumnPartSerde.SerializerBuilder
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.DoubleNumericColumnPartSerdeV2.SerializerBuilder
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.FloatNumericColumnPartSerde.SerializerBuilder
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.FloatNumericColumnPartSerdeV2.SerializerBuilder
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.LongNumericColumnPartSerde.SerializerBuilder
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.LongNumericColumnPartSerdeV2.SerializerBuilder
- SerializerBuilder() - Constructor for class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.SerializerBuilder
- SerializerUtils - Class in org.apache.druid.common.utils
- SerializerUtils() - Constructor for class org.apache.druid.common.utils.SerializerUtils
- 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.
- serializeWithType(JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- serializeWithType(FrameBasedInlineDataSource, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.apache.druid.query.FrameBasedInlineDataSourceSerializer
-
Required because
DataSource
is polymorphic - server(String) - Method in class org.apache.druid.query.DefaultQueryMetrics
- server(String) - Method in interface org.apache.druid.query.QueryMetrics
- server(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- SERVER - org.apache.druid.java.util.common.lifecycle.Lifecycle.Stage
- SERVICE_FAILURE - org.apache.druid.java.util.emitter.service.AlertEvent.Severity
- ServiceEmitter - Class in org.apache.druid.java.util.emitter.service
- ServiceEmitter(String, String, Emitter) - Constructor for class org.apache.druid.java.util.emitter.service.ServiceEmitter
- ServiceEmitter(String, String, Emitter, ImmutableMap<String, String>) - Constructor for class org.apache.druid.java.util.emitter.service.ServiceEmitter
- ServiceEventBuilder<X extends Event> - Class in org.apache.druid.java.util.emitter.service
- ServiceEventBuilder() - Constructor for class org.apache.druid.java.util.emitter.service.ServiceEventBuilder
- ServiceMetricEvent - Class in org.apache.druid.java.util.emitter.service
- ServiceMetricEvent.Builder - Class in org.apache.druid.java.util.emitter.service
-
Builder for a
ServiceMetricEvent
. - set(int, int) - Method in class org.apache.druid.extendedset.utilities.IntList
- 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(Object) - Method in class org.apache.druid.segment.virtual.SingleInputBindings
- set(String, byte[], T, AuditInfo) - Method in class org.apache.druid.common.config.JacksonConfigManager
-
Set the config and add audit entry
- set(String, ConfigSerde<T>, byte[], T) - Method in class org.apache.druid.common.config.ConfigManager
- set(String, ConfigSerde<T>, T) - Method in class org.apache.druid.common.config.ConfigManager
- set(String, T, AuditInfo) - Method in class org.apache.druid.common.config.JacksonConfigManager
-
Set the config and add audit entry
- set(Memory, long) - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryPointer
- set(InputRow) - Method in class org.apache.druid.segment.incremental.IncrementalIndex.InputRowHolder
- set(IncrementalIndexRow) - Method in class org.apache.druid.segment.incremental.IncrementalIndexRowHolder
- set(T) - Method in class org.apache.druid.common.guava.SettableSupplier
- set(T, long, long) - Method in class org.apache.druid.frame.allocation.MemoryRange
- setAccumulator(ExprEval<?>) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorInputBindings
- 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
- setAndCheckPosition(long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- setAndCheckStartPositionEnd(long, long, long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- setArrayIndex(Object, int, Object) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- setAt(int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.ByteBufferMinMaxOffsetHeap
- setBasicAuthentication(String, String) - Method in class org.apache.druid.java.util.http.client.Request
- setBasicAuthentication(PasswordProvider) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setBatchingStrategy(BatchingStrategy) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setBatchQueueSizeLimit(int) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setBits(long, byte) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- 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
- setByteBufferProvider(ByteBufferProvider) - Method in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexColumn.Builder
- setByteBufferProvider(ByteBufferProvider) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter.Builder
- setByteBufferProvider(ByteBufferProvider) - Method in class org.apache.druid.segment.serde.cell.CellReader.Builder
- setByteBufferProvider(ByteBufferProvider) - Method in class org.apache.druid.segment.serde.cell.CellWriter.Builder
- setByteBufferProvier(ByteBufferProvider) - Method in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexColumn.Builder
- setByteBufferProvier(ByteBufferProvider) - Method in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexColumn.Builder
- setByteBufferProvier(ByteBufferProvider) - Method in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexColumn.Builder
- setColumnFormat(ColumnFormat) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setComplexColumnSupplier(Supplier<? extends ComplexColumn>) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setComplexTypeName(String) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setCompressionStrategy(CompressionStrategy) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter.Builder
- setCompressionStrategy(CompressionStrategy) - Method in class org.apache.druid.segment.serde.cell.CellReader.Builder
- setCompressionStrategy(CompressionStrategy) - Method in class org.apache.druid.segment.serde.cell.CellWriter.Builder
-
change the compression strategy.
- setContent(byte[]) - Method in class org.apache.druid.java.util.http.client.Request
- setContent(String, byte[]) - Method in class org.apache.druid.java.util.http.client.Request
- setContent(String, byte[], int, int) - Method in class org.apache.druid.java.util.http.client.Request
- setContent(String, ChannelBuffer) - Method in class org.apache.druid.java.util.http.client.Request
- setContent(ChannelBuffer) - Method in class org.apache.druid.java.util.http.client.Request
- setContentEncoding(ContentEncoding) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setContext(Map<String, Object>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setCreatedTime(DateTime) - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent.Builder
- setCurrentFactory(int) - Method in class org.apache.druid.frame.processor.MultiColumnSelectorFactory
- setCurrentOffset(int) - Method in class org.apache.druid.frame.segment.FrameFilteredOffset
- 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
- setCurrentRow(int) - Method in class org.apache.druid.frame.segment.FrameCursor
-
Moves this cursor to a particular row number.
- setDataSource(String) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setDataSource(DataSource) - 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
- setDefaultSchemaDimensions(List<String>) - Method in class org.apache.druid.data.input.impl.DimensionsSpec.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.java.util.emitter.service.ServiceMetricEvent.Builder
- setDimension(String, Object) - Method in class org.apache.druid.query.DefaultQueryMetrics
- setDimension(String, String[]) - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent.Builder
- setDimensionExclusions(List<String>) - Method in class org.apache.druid.data.input.impl.DimensionsSpec.Builder
- setDimensionIfNotNull(String, Object) - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent.Builder
- setDimensions(List<DimensionSchema>) - Method in class org.apache.druid.data.input.impl.DimensionsSpec.Builder
- 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
- setError(Throwable) - Method in class org.apache.druid.frame.channel.ReadableByteChunksFrameChannel
-
Clears the channel and replaces it with the given error.
- setFeed(String) - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent.Builder
- setFieldNames(Iterable<String>) - Method in class org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser
- setFieldNames(Iterable<String>) - Method in class org.apache.druid.java.util.common.parsers.JavaScriptParser
- setFieldNames(Iterable<String>) - Method in class org.apache.druid.java.util.common.parsers.JSONPathParser
- setFieldNames(Iterable<String>) - Method in class org.apache.druid.java.util.common.parsers.JSONToLowerParser
-
Deprecated.
- setFieldNames(Iterable<String>) - Method in interface org.apache.druid.java.util.common.parsers.Parser
-
Deprecated.
- setFieldNames(Iterable<String>) - Method in class org.apache.druid.java.util.common.parsers.RegexParser
- setFieldNames(String) - Method in class org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser
- setFileMapper(SmooshedFileMapper) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setFlushCount(int) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setFlushMillis(long) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setFlushTimeout(long) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- 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
- setHasMultipleValues(ColumnCapabilities.Capable) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- setHasNulls(boolean) - 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.ColumnBuilder
- setHasNulls(ColumnCapabilities.Capable) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- setHasObjects() - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
- setHasSpatialIndexes(boolean) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- setHavingSpec(HavingSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setHeader(String, String) - Method in class org.apache.druid.java.util.http.client.Request
- setHttpTimeoutAllowanceFactor(float) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setIncludeAllDimensions(boolean) - Method in class org.apache.druid.data.input.impl.DimensionsSpec.Builder
- setIndexSchema(IncrementalIndexSchema) - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- setIndexSupplier(ColumnIndexSupplier, boolean, boolean) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setInterval(String) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setInterval(List<Interval>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setInterval(QuerySegmentSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setInterval(Interval) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setKey(KeyType) - Method in class org.apache.druid.query.groupby.epinephelinae.ReusableEntry
-
Replaces the key completely.
- setLegacy(boolean) - Method in class org.apache.druid.query.scan.ScanQueryConfig
- setLifecycle(Lifecycle) - Method in class org.apache.druid.guice.LifecycleScope
- setLimit(int) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setLimitSpec(LimitSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setMaxBatchSize(int) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setMaxBytesInMemory(long) - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- setMaxOverflowRegister(short) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setMaxOverflowRegister(short) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setMaxOverflowRegister(short) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- setMaxOverflowRegister(ByteBuffer, short) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setMaxOverflowRegister(ByteBuffer, short) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setMaxOverflowRegister(ByteBuffer, short) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- setMaxOverflowValue(byte) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setMaxOverflowValue(byte) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setMaxOverflowValue(byte) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- setMaxOverflowValue(ByteBuffer, byte) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setMaxOverflowValue(ByteBuffer, byte) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setMaxOverflowValue(ByteBuffer, byte) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- setMaxRowCount(int) - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- setMetric(String, Number) - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent.Builder
- setMinHttpTimeoutMillis(int) - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig.Builder
- setNestedCommonFormatColumnSupplier(Supplier<? extends NestedCommonFormatColumn>) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setNullValueIndexSupplier(ImmutableBitmap) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setNumericColumnSupplier(Supplier<? extends NumericColumn>) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setNumNonZeroRegisters(short) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setNumNonZeroRegisters(short) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setNumNonZeroRegisters(short) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- setNumNonZeroRegisters(ByteBuffer, short) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setNumNonZeroRegisters(ByteBuffer, short) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setNumNonZeroRegisters(ByteBuffer, short) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- setObjectMapper(ObjectMapper) - Method in class org.apache.druid.indexer.report.SingleFileTaskReportFileWriter
- setObjectMapper(ObjectMapper) - Method in interface org.apache.druid.indexer.report.TaskReportFileWriter
- setObjectsNotSorted() - Method in class org.apache.druid.segment.data.GenericIndexedWriter
- setOffsetLimit(OffsetLimit) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- setOffsetLimit(OffsetLimit) - Method in interface org.apache.druid.query.rowsandcols.semantic.RowsAndColumnsDecorator
- setOrdering(List<ColumnWithDirection>) - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- setOrdering(List<ColumnWithDirection>) - Method in interface org.apache.druid.query.rowsandcols.semantic.RowsAndColumnsDecorator
- 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
- setPosition(long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- setPositionAndLength(long, long) - Method in class org.apache.druid.frame.field.SettableFieldPointer
-
Sets the position and the length to be returned when interface's methods are called.
- setPostAggregatorSpecs(List<PostAggregator>) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setPostAggregatorSpecs(PostAggregator...) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setPreserveExistingMetrics(boolean) - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- setProperty(Object, Object, Object) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- 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
- setRegisterOffset(byte) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setRegisterOffset(byte) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setRegisterOffset(byte) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- setRegisterOffset(ByteBuffer, byte) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setRegisterOffset(ByteBuffer, byte) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setRegisterOffset(ByteBuffer, byte) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- 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(Boolean, Boolean, AggregatorFactory...) - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
-
A helper method to set a simple index schema with controllable metrics and rollup, and default values for the other parameters.
- setSimpleTestingIndexSchema(AggregatorFactory...) - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
-
A helper method to set a simple index schema with only metrics 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
- setSparseIndexed() - Method in class org.apache.druid.segment.AutoTypeColumnIndexer
- setSparseIndexed() - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- 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.NestedDataColumnIndexerV4
- setSpatialDimensions(List<SpatialDimensionSchema>) - Method in class org.apache.druid.data.input.impl.DimensionsSpec.Builder
-
Deprecated.
- setSpillingAllowed(boolean) - Method in class org.apache.druid.query.groupby.epinephelinae.SpillingGrouper
- setStartPositionEnd(long, long, long) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- setStatus(String, boolean, StatusType) - Method in interface org.apache.druid.metadata.MetadataStorageActionHandler
-
Sets or updates the status for any active entry with the given id.
- 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
. - SettableCursorColumnSelectorFactory - Class in org.apache.druid.query.scan
-
A column selector factory, that represents the column values from multiple underlying cursors.
- SettableCursorColumnSelectorFactory(Supplier<Cursor>, RowSignature) - Constructor for class org.apache.druid.query.scan.SettableCursorColumnSelectorFactory
- 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
- SettableFieldPointer - Class in org.apache.druid.frame.field
-
A simple
ReadableFieldPointer
that returns the position and the length that was set on its object. - SettableFieldPointer() - Constructor for class org.apache.druid.frame.field.SettableFieldPointer
- 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
- SettableLongVirtualColumn - Class in org.apache.druid.frame.util
-
Virtual column that returns a changeable value, via
SettableLongVirtualColumn.setValue(long)
. - SettableLongVirtualColumn(String) - Constructor for class org.apache.druid.frame.util.SettableLongVirtualColumn
- SettableObjectBinding - Class in org.apache.druid.math.expr
-
Simple map backed object binding
- SettableObjectBinding() - Constructor for class org.apache.druid.math.expr.SettableObjectBinding
- SettableObjectBinding(int) - Constructor for class org.apache.druid.math.expr.SettableObjectBinding
- SettableObjectColumnValueSelector<T> - Class in org.apache.druid.segment.selector.settable
- SettableObjectColumnValueSelector() - Constructor for class org.apache.druid.segment.selector.settable.SettableObjectColumnValueSelector
- SettableSupplier<T> - Class in org.apache.druid.common.guava
-
A settable Supplier.
- SettableSupplier() - Constructor for class org.apache.druid.common.guava.SettableSupplier
- SettableSupplier(T) - Constructor for class org.apache.druid.common.guava.SettableSupplier
- 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
- setToString(String) - Method in class org.apache.druid.query.FluentQueryRunner
-
Sets the toString of the QueryRunner.
- setTotalMergersForLevel(int, long) - Method in class org.apache.druid.frame.processor.SuperSorterProgressTracker
-
Sets the total mergers for a level.
- setTotalMergersForUltimateLevel(long) - Method in class org.apache.druid.frame.processor.SuperSorterProgressTracker
-
Sets the number of mergers in the ultimate level (number of mergers = number of output partitions).
- setTotalMergingLevels(int) - Method in class org.apache.druid.frame.processor.SuperSorterProgressTracker
-
Set total merging levels for the SuperSorter it is tracking.
- setType(ColumnType) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setType(ColumnType) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- setType(TypeSignature<ValueType>) - Method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
- setType(ValueType) - Method in class org.apache.druid.segment.column.ColumnBuilder
- setupAnnotationIntrospector(ObjectMapper, AnnotationIntrospector) - Static method in class org.apache.druid.guice.DruidSecondaryModule
- setupEncodedValueWriter() - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- setupJackson(Injector, ObjectMapper) - Static method in class org.apache.druid.guice.DruidSecondaryModule
- setUseMaxMemoryEstimates(boolean) - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- 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(int) - Method in class org.apache.druid.query.groupby.epinephelinae.IntKey
- setValue(int) - Method in class org.apache.druid.segment.data.SingleIndexedInt
- setValue(int, int) - Method in class org.apache.druid.segment.data.ArrayBasedIndexedInts
- setValue(long) - Method in class org.apache.druid.frame.util.SettableLongVirtualColumn
- 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(long) - Method in class org.apache.druid.segment.selector.settable.SettableValueLongColumnValueSelector
- setValueFrom(ColumnValueSelector) - Method in class org.apache.druid.segment.selector.settable.SettableObjectColumnValueSelector
- 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
- setValueMatcher(ValueMatcher) - Method in class org.apache.druid.segment.join.PostJoinCursor
- 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
- setValues(Object[]) - Method in class org.apache.druid.query.groupby.epinephelinae.ReusableEntry
-
Replaces the values array completely.
- setValueType(ValueType) - Method in class org.apache.druid.segment.column.ColumnDescriptor.Builder
- setVersion(ByteBuffer) - Method in class org.apache.druid.hll.HyperLogLogCollector
- setVersion(ByteBuffer) - Method in class org.apache.druid.hll.VersionOneHyperLogLogCollector
- setVersion(ByteBuffer) - Method in class org.apache.druid.hll.VersionZeroHyperLogLogCollector
-
Deprecated.
- setVirtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- setVirtualColumns(VirtualColumns) - Method in class org.apache.druid.query.groupby.GroupByQuery.Builder
- severity - Variable in class org.apache.druid.java.util.emitter.service.AlertBuilder
- severity(AlertEvent.Severity) - Method in class org.apache.druid.java.util.emitter.service.AlertBuilder
- shardSpec(ShardSpec) - Method in class org.apache.druid.timeline.DataSegment.Builder
- ShardSpec - Interface in org.apache.druid.timeline.partition
-
A Marker interface that exists to combine ShardSpec objects together for Jackson.
- ShardSpec.Type - Interface in org.apache.druid.timeline.partition
-
ShardSpec type names.
- ShardSpecLookup - Interface in org.apache.druid.timeline.partition
- sharePartitionSpace(PartialShardSpec) - Method in interface org.apache.druid.timeline.partition.OverwriteShardSpec
-
Returns true if this shardSpec and the given
PartialShardSpec
share the same partition space. - sharePartitionSpace(PartialShardSpec) - Method in interface org.apache.druid.timeline.partition.ShardSpec
-
Returns true if this shardSpec and the given
PartialShardSpec
share the same partition space. - ShiftedColumnAccessorBase - Class in org.apache.druid.query.operator.window.value
- ShiftedColumnAccessorBase(ColumnAccessor) - Constructor for class org.apache.druid.query.operator.window.value.ShiftedColumnAccessorBase
- shouldAggregateNullInputs() - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory.FactorizePlan
- shouldReschedule(List<Boolean>) - Method in class org.apache.druid.java.util.metrics.CompoundMonitor
- shouldRetryPredicate() - Method in interface org.apache.druid.segment.loading.URIDataPuller
-
Evaluates a Throwable to see if it is recoverable.
- 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.java.util.common.concurrent.DirectExecutorService
- shutdown() - Method in class org.apache.druid.query.PrioritizedExecutorService
- shutdownNow() - Method in class org.apache.druid.java.util.common.concurrent.DirectExecutorService
- shutdownNow() - Method in class org.apache.druid.query.PrioritizedExecutorService
- SideEffectHandlerRegisterer() - Constructor for class org.apache.druid.guice.NestedDataModule.SideEffectHandlerRegisterer
- SigarPidDiscoverer - Class in org.apache.druid.java.util.metrics
- SigarUtil - Class in org.apache.druid.java.util.metrics
- SigarUtil() - Constructor for class org.apache.druid.java.util.metrics.SigarUtil
- signature() - Method in class org.apache.druid.frame.read.FrameReader
- signature() - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriterFactory
- signature() - Method in interface org.apache.druid.frame.write.FrameWriterFactory
- signature() - Method in class org.apache.druid.frame.write.RowBasedFrameWriterFactory
- signum(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Signum() - Constructor for class org.apache.druid.math.expr.Function.Signum
- simple(Iterable<T>) - Static method in class org.apache.druid.java.util.common.guava.Sequences
- SimpleAscendingOffset - Class in org.apache.druid.segment
- SimpleAscendingOffset(int) - Constructor for class org.apache.druid.segment.SimpleAscendingOffset
- SimpleBitmapColumnIndex - Class in org.apache.druid.segment.index
-
BitmapColumnIndex
with Druids "default"ColumnIndexCapabilities
. - SimpleBitmapColumnIndex() - Constructor for class org.apache.druid.segment.index.SimpleBitmapColumnIndex
- SimpleColumnIndexCapabilities - Class in org.apache.druid.segment.column
- SimpleColumnIndexCapabilities(boolean, boolean) - Constructor for class org.apache.druid.segment.column.SimpleColumnIndexCapabilities
- SimpleDescendingOffset - Class in org.apache.druid.segment
- SimpleDescendingOffset(int) - Constructor for class org.apache.druid.segment.SimpleDescendingOffset
- SimpleDictionaryMergingIterator<T extends Comparable<T>> - Class in org.apache.druid.segment
- SimpleDictionaryMergingIterator(Indexed<T>[], Comparator<PeekingIterator<T>>) - Constructor for class org.apache.druid.segment.SimpleDictionaryMergingIterator
- 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
- SimpleImmutableBitmapDelegatingIterableIndex - Class in org.apache.druid.segment.index
- SimpleImmutableBitmapDelegatingIterableIndex() - Constructor for class org.apache.druid.segment.index.SimpleImmutableBitmapDelegatingIterableIndex
- SimpleImmutableBitmapIndex - Class in org.apache.druid.segment.index
-
SimpleBitmapColumnIndex
which wraps a singleImmutableBitmap
with no 'unknowns', e.g. - SimpleImmutableBitmapIndex(ImmutableBitmap) - Constructor for class org.apache.druid.segment.index.SimpleImmutableBitmapIndex
- SimpleImmutableBitmapIterableIndex - Class in org.apache.druid.segment.index
-
SimpleBitmapColumnIndex
for anything which can compute anIterable
in some manner - SimpleImmutableBitmapIterableIndex() - Constructor for class org.apache.druid.segment.index.SimpleImmutableBitmapIterableIndex
- SimpleIndexBundle(FilterBundle.IndexBundleInfo, ImmutableBitmap, ColumnIndexCapabilities) - Constructor for class org.apache.druid.query.filter.FilterBundle.SimpleIndexBundle
- 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
- SimpleMatcherBundle(FilterBundle.MatcherBundleInfo, Function<ColumnSelectorFactory, ValueMatcher>, Function<VectorColumnSelectorFactory, VectorValueMatcher>) - Constructor for class org.apache.druid.query.filter.FilterBundle.SimpleMatcherBundle
- 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
- SimpleRowIngestionMeters - Class in org.apache.druid.segment.incremental
- SimpleRowIngestionMeters() - Constructor for class org.apache.druid.segment.incremental.SimpleRowIngestionMeters
- SimpleSequence<T> - Class in org.apache.druid.java.util.common.guava
-
Simple Sequence based on an Iterable, created using
Sequences.simple(java.lang.Iterable<T>)
. - SimpleSettableOffset - Class in org.apache.druid.segment
- SimpleSettableOffset() - Constructor for class org.apache.druid.segment.SimpleSettableOffset
- sin(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Sin() - Constructor for class org.apache.druid.math.expr.Function.Sin
- SINGLE - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- SINGLE_INPUT_MAPPABLE - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression has a single input, which may produce single or multi-valued output, but if so, it must be implicitly mappable (i.e.
- SINGLE_INPUT_SCALAR - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression has a single, single valued input, and is dictionary encoded if the value is a string, and does not produce non-scalar output
- SINGLE_VALUE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- SingleDimensionPartialShardSpec - Class in org.apache.druid.timeline.partition
- SingleDimensionPartialShardSpec(String, int, String, String, int) - Constructor for class org.apache.druid.timeline.partition.SingleDimensionPartialShardSpec
- SingleDimensionPartitionsSpec - Class in org.apache.druid.indexer.partitions
-
Partition a segment by a single dimension.
- SingleDimensionPartitionsSpec(Integer, Integer, String, boolean) - Constructor for class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
- SingleDimensionPartitionsSpec(Integer, Integer, String, boolean, Integer, Integer) - Constructor for class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
- SingleDimensionRangeBucketShardSpec - Class in org.apache.druid.timeline.partition
-
See
BucketNumberedShardSpec
for how this class is used. - SingleDimensionRangeBucketShardSpec(int, String, String, String) - Constructor for class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- SingleDimensionShardSpec - Class in org.apache.druid.timeline.partition
-
ShardSpec
for range partitioning based on a single dimension - SingleDimensionShardSpec(String, String, String, int, Integer) - Constructor for class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- SingleElementPartitionChunk<T> - Class in org.apache.druid.timeline.partition
-
Deprecated.
- SingleElementPartitionChunk(T) - Constructor for class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- SingleFileTaskReportFileWriter - Class in org.apache.druid.indexer.report
- SingleFileTaskReportFileWriter(File) - Constructor for class org.apache.druid.indexer.report.SingleFileTaskReportFileWriter
- 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(ExpressionType) - 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, RowIdSupplier) - Constructor for class org.apache.druid.segment.virtual.SingleLongInputCachingExpressionColumnValueSelector
- SingleLongInputCachingExpressionColumnValueSelector.LruEvalCache - Class in org.apache.druid.segment.virtual
- SingleMemoryAllocatorFactory - Class in org.apache.druid.frame.allocation
-
Wraps a single
MemoryAllocator
. - SingleMemoryAllocatorFactory(MemoryAllocator) - Constructor for class org.apache.druid.frame.allocation.SingleMemoryAllocatorFactory
- 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
- SingleStringFirstDimensionVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- SingleStringFirstDimensionVectorAggregator(VectorValueSelector, SingleValueDimensionVectorSelector, int) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.SingleStringFirstDimensionVectorAggregator
- SingleStringFirstLastDimensionVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast
- SingleStringFirstLastDimensionVectorAggregator(VectorValueSelector, SingleValueDimensionVectorSelector, int, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.SingleStringFirstLastDimensionVectorAggregator
- 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, RowIdSupplier) - Constructor for class org.apache.druid.segment.virtual.SingleStringInputCachingExpressionColumnValueSelector
- SingleStringInputCachingExpressionColumnValueSelector.LruEvalCache - Class in org.apache.druid.segment.virtual
- SingleStringInputDeferredEvaluationExpressionDimensionSelector - Class in org.apache.druid.segment.virtual
-
A
DimensionSelector
decorator that directly exposes the underlying dictionary id inSingleStringInputDeferredEvaluationExpressionDimensionSelector.getRow()
, saving expression computation untilSingleStringInputDeferredEvaluationExpressionDimensionSelector.lookupName(int)
is called. - SingleStringInputDeferredEvaluationExpressionDimensionSelector(DimensionSelector, Expr) - Constructor for class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionSelector
- SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector - Class in org.apache.druid.segment.virtual
-
A
SingleValueDimensionVectorSelector
decorator that directly exposes the underlying dictionary ids inSingleStringInputDeferredEvaluationExpressionDimensionVectorSelector.getRowVector()
, saving expression computation untilSingleStringInputDeferredEvaluationExpressionDimensionVectorSelector.lookupName(int)
is called. - SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector(SingleValueDimensionVectorSelector, Expr) - Constructor for class org.apache.druid.segment.virtual.SingleStringInputDeferredEvaluationExpressionDimensionVectorSelector
- SingleStringLastDimensionVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- SingleStringLastDimensionVectorAggregator(VectorValueSelector, SingleValueDimensionVectorSelector, int) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.SingleStringLastDimensionVectorAggregator
- singleThreaded() - Method in class org.apache.druid.segment.data.GenericIndexed
- singleThreaded(String) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- singleThreaded(String, Integer) - Static method in class org.apache.druid.java.util.common.concurrent.Execs
- singleThreaded(Expr, Expr.InputBindingInspector) - Static method in interface org.apache.druid.math.expr.Expr
-
Returns the single-threaded version of the given expression tree.
- SINGLETON - Static variable in class org.apache.druid.guice.DruidScopes
- SingleValueAggregator - Class in org.apache.druid.query.aggregation
- SingleValueAggregator(ColumnValueSelector) - Constructor for class org.apache.druid.query.aggregation.SingleValueAggregator
- SingleValueAggregatorFactory - Class in org.apache.druid.query.aggregation
-
This AggregatorFactory is meant to wrap the subquery used as an expression into a single value and is expected to throw an exception when the subquery results in more than one row
- SingleValueAggregatorFactory(String, String, ColumnType) - Constructor for class org.apache.druid.query.aggregation.SingleValueAggregatorFactory
- SingleValueBufferAggregator - Class in org.apache.druid.query.aggregation
- SingleValueBufferAggregator(ColumnValueSelector, ColumnType) - Constructor for class org.apache.druid.query.aggregation.SingleValueBufferAggregator
- 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
- SingleValueStringCardinalityVectorProcessor - Class in org.apache.druid.query.aggregation.cardinality.vector
- SingleValueStringCardinalityVectorProcessor(SingleValueDimensionVectorSelector) - Constructor for class org.apache.druid.query.aggregation.cardinality.vector.SingleValueStringCardinalityVectorProcessor
- 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
- sinh(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Sinh() - Constructor for class org.apache.druid.math.expr.Function.Sinh
- SinkQueryRunners<T> - Class in org.apache.druid.query
- SinkQueryRunners(Iterable<Pair<Interval, QueryRunner<T>>>) - Constructor for class org.apache.druid.query.SinkQueryRunners
- SIX_HOUR - org.apache.druid.java.util.common.granularity.GranularityType
- SIX_HOUR - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- size - Variable in class org.apache.druid.query.groupby.epinephelinae.ByteBufferHashTable
- size - Variable in class org.apache.druid.segment.data.GenericIndexed
- 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.RangeIntSet
- size() - Method in class org.apache.druid.collections.spatial.ImmutableRTree
- size() - Method in class org.apache.druid.collections.StableLimitingSorter
-
Returns the number of elements currently in the sorter.
- size() - Method in class org.apache.druid.data.input.StringTuple
- size() - Method in class org.apache.druid.extendedset.intset.AbstractIntSet
- size() - Method in class org.apache.druid.extendedset.intset.ConciseSet
- size() - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- size() - Method in interface org.apache.druid.extendedset.intset.IntSet
- size() - Method in class org.apache.druid.frame.allocation.AppendableMemory
- size() - Method in class org.apache.druid.frame.key.ClusterByPartitions
- size() - Method in class org.apache.druid.frame.write.columnar.ComplexFrameColumnWriter
- size() - Method in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- size() - Method in class org.apache.druid.frame.write.columnar.DoubleFrameColumnWriter
- size() - Method in class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- size() - Method in class org.apache.druid.frame.write.columnar.FloatFrameColumnWriter
- size() - Method in class org.apache.druid.frame.write.columnar.FloatFrameMaker
- size() - Method in interface org.apache.druid.frame.write.columnar.FrameColumnWriter
-
Size (in bytes) of the column data that will get written when
FrameColumnWriter.writeTo(org.apache.datasketches.memory.WritableMemory, long)
will be called - size() - Method in class org.apache.druid.frame.write.columnar.LongFrameColumnWriter
- size() - Method in class org.apache.druid.frame.write.columnar.LongFrameMaker
- size() - Method in class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
- size() - Method in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
- size() - Method in class org.apache.druid.java.util.common.FileUtils.FileCopyResult
- size() - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
- size() - Method in class org.apache.druid.math.expr.CartesianList
- size() - Method in class org.apache.druid.query.aggregation.AggregatorAdapters
-
Return the number of aggregators in this object.
- 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.column.StringEncodingStrategies.Utf8ToStringIndexed
- size() - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
- 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 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.CompressedLongsReader
- size() - Method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumn
- 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.FixedIndexed
- size() - Method in class org.apache.druid.segment.data.FrontCodedIndexed
- size() - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexed
- size() - Method in class org.apache.druid.segment.data.GenericIndexed.BufferIndexed
- 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
-
Number of elements in the value set
- 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.DimensionDictionary
- size() - Method in class org.apache.druid.segment.incremental.IncrementalIndex
- size() - Method in class org.apache.druid.segment.nested.LocalDimensionDictionary
- size() - Method in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
- size() - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesColumnarMultiInts
- size() - Method in class org.apache.druid.segment.serde.CombineFirstTwoValuesIndexedInts
- size() - Method in class org.apache.druid.segment.serde.ReplaceFirstValueWithNullIndexed
- 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.
- size() - Method in class org.apache.druid.utils.CircularBuffer
- size(long) - Method in class org.apache.druid.timeline.DataSegment.Builder
- 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 - org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
- SIZE_WORTH_CHECKING_MIN - Static variable in interface org.apache.druid.segment.index.semantic.ValueSetIndexes
-
minimum sorted match value iterator size to trim the initial values from the iterator to seek to the start of the value dictionary when using
ValueSetIndexes.buildBitmapColumnIndexFromSortedIteratorScan(org.apache.druid.collections.bitmap.BitmapFactory, java.util.Comparator<T>, java.lang.Iterable<T>, org.apache.druid.segment.data.Indexed<T>, org.apache.druid.segment.data.Indexed<org.apache.druid.collections.bitmap.ImmutableBitmap>, com.google.common.base.Supplier<org.apache.druid.collections.bitmap.ImmutableBitmap>)
orValueSetIndexes.buildBitmapColumnIndexFromSortedIteratorBinarySearch(org.apache.druid.collections.bitmap.BitmapFactory, java.lang.Iterable<T>, org.apache.druid.segment.data.Indexed<T>, org.apache.druid.segment.data.Indexed<org.apache.druid.collections.bitmap.ImmutableBitmap>, com.google.common.base.Supplier<org.apache.druid.collections.bitmap.ImmutableBitmap>)
. - SizeFormatFunc() - Constructor for class org.apache.druid.math.expr.Function.SizeFormatFunc
- sizeInBytes() - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
-
Gets the current size of this dictionary in bytes.
- sizeInBytes() - Method in class org.apache.druid.segment.DimensionDictionary
-
Gets the current size of this dictionary in bytes.
- sizeInBytes() - Method in class org.apache.druid.segment.nested.ValueDictionary
- SKETCH_MERGE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- skip(long) - Method in class org.apache.druid.data.input.impl.RetryingInputStream
- skip(long) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- skip(long) - Method in class org.apache.druid.java.util.http.client.io.AppendableByteArrayInputStream
- 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
- skipAllBefore(int) - Method in class org.apache.druid.extendedset.intset.BitIterator
- skipAllBefore(int) - Method in class org.apache.druid.extendedset.intset.EmptyIntIterator
- skipAllBefore(int) - Method in interface org.apache.druid.extendedset.intset.IntSet.IntIterator
-
Skips all the elements before the specified element, so that
IntSet.IntIterator.next()
gives the given element or, if it does not exist, the element immediately after according to the sorting provided by this set. - SkippingSequence<T> - Class in org.apache.druid.java.util.common.guava
-
A Sequence that skips the first few elements.
- SkippingSequence(Sequence<T>, long) - Constructor for class org.apache.druid.java.util.common.guava.SkippingSequence
- 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
- skipValueRangeIndexScale() - Method in class org.apache.druid.query.DruidProcessingConfig
- skipValueRangeIndexScale() - Method in interface org.apache.druid.segment.column.ColumnConfig
-
If the number of selected rows in a column multiplied by this value is smaller than the total number of bitmap index operations required to perform to use
NumericRangeIndexes
, then for anyColumnIndexSupplier
which chooses to participate in this config it will skip computing the index, indicated by a return value of null from the 'forRange' methods, to force the filter to be processed with a scan using aValueMatcher
instead. - sleepFor(long, TimeUnit) - Static method in class org.apache.druid.concurrent.Threads
-
Equivalent of
Thread.sleep(long)
with arguments and semantics of timed wait methods in classes fromjava.util.concurrent
(likeSemaphore.tryAcquire(long, TimeUnit)
,Lock.tryLock(long, TimeUnit)
, etc.): if the sleepTime argument is negative or zero, the method returns immediately. - 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.
- Smile - Annotation Type in org.apache.druid.guice.annotations
- smileMapper(Properties) - Method in class org.apache.druid.jackson.JacksonModule
- Smoosh - Class in org.apache.druid.java.util.common.io.smoosh
- Smoosh() - Constructor for class org.apache.druid.java.util.common.io.smoosh.Smoosh
- SmooshedFileMapper - Class in org.apache.druid.java.util.common.io.smoosh
-
Class that works in conjunction with FileSmoosher.
- SmooshedWriter - Interface in org.apache.druid.java.util.common.io.smoosh
- SNAPPY - org.apache.druid.utils.CompressionUtils.Format
- snapshot() - Method in class org.apache.druid.frame.processor.SuperSorterProgressTracker
- snapshot() - Method in class org.apache.druid.java.util.metrics.cgroups.Cpu
-
Take a snapshot of cpu cgroup data
- snapshot() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct
-
Take a snapshot of the existing data.
- snapshot() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuSet
-
Take a snapshot of cpuset cgroup data
- snapshot() - Method in class org.apache.druid.java.util.metrics.cgroups.Memory
- snapshot(ColumnCapabilities, ColumnCapabilities.CoercionLogic) - Static method in class org.apache.druid.segment.column.ColumnCapabilitiesImpl
-
Copy a
ColumnCapabilities
and coerce allColumnCapabilities.Capable.UNKNOWN
toColumnCapabilities.Capable.TRUE
orColumnCapabilities.Capable.FALSE
as specified byColumnCapabilities.CoercionLogic
- SocketUtil - Class in org.apache.druid.common.utils
- SocketUtil() - Constructor for class org.apache.druid.common.utils.SocketUtil
- sort() - Method in class org.apache.druid.segment.ComparatorDimensionDictionary
- sort() - Method in class org.apache.druid.segment.DimensionDictionary
- sort(ArrayList<ColumnWithDirection>) - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- sort(Frame, FrameReader, List<KeyColumn>) - Static method in class org.apache.druid.frame.write.FrameSort
-
Sort the given frame in-place.
- sort(Sequence<T>, Comparator<T>) - Static method in class org.apache.druid.java.util.common.guava.Sequences
-
Returns a sorted copy of the provided sequence.
- sortable() - Method in class org.apache.druid.frame.key.ClusterBy
-
Whether this key is sortable.
- sortable() - Method in enum org.apache.druid.frame.key.KeyOrder
- sortableSignature(RowSignature, List<KeyColumn>) - Static method in class org.apache.druid.frame.write.FrameWriters
-
Returns a copy of "signature" with columns rearranged so the provided sortColumns appear as a prefix.
- SORTED_ARRAY - org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
- SORTED_SCAN_RATIO_THRESHOLD - Static variable in interface org.apache.druid.segment.index.semantic.ValueSetIndexes
-
threshold of sorted match value iterator size compared to dictionary size to use
ValueSetIndexes.buildBitmapColumnIndexFromSortedIteratorScan(org.apache.druid.collections.bitmap.BitmapFactory, java.util.Comparator<T>, java.lang.Iterable<T>, org.apache.druid.segment.data.Indexed<T>, org.apache.druid.segment.data.Indexed<org.apache.druid.collections.bitmap.ImmutableBitmap>, com.google.common.base.Supplier<org.apache.druid.collections.bitmap.ImmutableBitmap>)
instead ofValueSetIndexes.buildBitmapColumnIndexFromSortedIteratorBinarySearch(org.apache.druid.collections.bitmap.BitmapFactory, java.lang.Iterable<T>, org.apache.druid.segment.data.Indexed<T>, org.apache.druid.segment.data.Indexed<org.apache.druid.collections.bitmap.ImmutableBitmap>, com.google.common.base.Supplier<org.apache.druid.collections.bitmap.ImmutableBitmap>)
. - SORTED_SET - org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
- SortedDimensionDictionary<T extends Comparable<T>> - Class in org.apache.druid.segment
-
Creates a sorted dictionary given some existing dictionary, storing a mapping of both sorted id to unsorted id and unsorted id to sorted id
- SortedDimensionDictionary(List<T>, int) - Constructor for class org.apache.druid.segment.SortedDimensionDictionary
- SortedInnerJoinOperator - Class in org.apache.druid.query.operator.join
-
An operator that can join the data streams from other operators.
- SortedInnerJoinOperator(List<JoinPartDefn>, JoinConfig) - Constructor for class org.apache.druid.query.operator.join.SortedInnerJoinOperator
- sortedLookup - Variable in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- sortedLookup() - Method in class org.apache.druid.segment.DictionaryEncodedColumnIndexer
- SortedMatrixMaker - Interface in org.apache.druid.query.rowsandcols.semantic
-
A thing that makes Matrixs in an assumed sorted-fashion.
- SortedMatrixMaker.SortedMatrix - Interface in org.apache.druid.query.rowsandcols.semantic
-
A matrix thingie
- SortedMatrixMaker.SortedMatrix.MatrixRow - Interface in org.apache.druid.query.rowsandcols.semantic
- SortedValueDictionary - Class in org.apache.druid.segment.nested
-
Container to collect a set of sorted
Indexed
representing the global value dictionaries of someNestedDataComplexColumn
, to later use withDictionaryMergingIterator
to merge into a new global dictionary - SortedValueDictionary(Indexed<String>, Indexed<Long>, Indexed<Double>, Indexed<Object[]>, Closeable) - Constructor for class org.apache.druid.segment.nested.SortedValueDictionary
- 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
- source() - Method in class org.apache.druid.data.input.impl.JsonNodeReader
- source() - Method in class org.apache.druid.data.input.impl.JsonReader
- source() - Method in class org.apache.druid.data.input.IntermediateRowParsingReader
- source() - Method in class org.apache.druid.data.input.TextReader
- source(String) - Method in class org.apache.druid.frame.write.InvalidFieldException.Builder
- source(String) - Method in class org.apache.druid.frame.write.InvalidNullByteException.Builder
- SPACE_MATCH - Static variable in class org.apache.druid.java.util.metrics.CgroupUtil
- 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.
- SPATIAL_TYPE_NAME - Static variable in class org.apache.druid.data.input.impl.DimensionSchema
- 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
- SpatialDimensionSchema - Class in org.apache.druid.data.input.impl
-
Deprecated.
- SpatialDimensionSchema(String, List<String>) - Constructor for class org.apache.druid.data.input.impl.SpatialDimensionSchema
-
Deprecated.
- SpatialDimFilter - Class in org.apache.druid.query.filter
- SpatialDimFilter(String, Bound) - Constructor for class org.apache.druid.query.filter.SpatialDimFilter
- SpatialDimFilter(String, Bound, FilterTuning) - 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.index.semantic
- SpatialIndexesMerger() - Constructor for class org.apache.druid.segment.StringDimensionMergerV9.SpatialIndexesMerger
- Spec() - Constructor for class org.apache.druid.segment.incremental.OnheapIncrementalIndex.Spec
- Spec(Boolean) - Constructor for class org.apache.druid.segment.incremental.OnheapIncrementalIndex.Spec
- 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
- SPECTATOR_HISTOGRAM_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- SPECTATOR_HISTOGRAM_DISTRIBUTION_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- SPECTATOR_HISTOGRAM_SKETCH_PERCENTILE_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- SPECTATOR_HISTOGRAM_SKETCH_PERCENTILES_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
- SPECTATOR_HISTOGRAM_TIMER_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- 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(byte[], byte, int) - Static method in class org.apache.druid.data.input.impl.DelimitedBytes
-
Split UTF-8 bytes by a particular delimiter.
- split(Iterator<T>, Function<T, InputFileAttribute>) - Method in class org.apache.druid.data.input.FilePerSplitHintSpec
- split(Iterator<T>, Function<T, InputFileAttribute>) - Method in class org.apache.druid.data.input.MaxSizeSplitHintSpec
- split(Iterator<T>, Function<T, InputFileAttribute>) - Method in class org.apache.druid.data.input.SegmentsSplitHintSpec
- split(Iterator<T>, Function<T, InputFileAttribute>) - Method in interface org.apache.druid.data.input.SplitHintSpec
-
Returns an iterator of splits.
- 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
- splitFilter(JoinFilterPreAnalysis, Filter) - Static method in class org.apache.druid.segment.join.filter.JoinFilterAnalyzer
- SplitHintSpec - Interface in org.apache.druid.data.input
-
In native parallel indexing, the supervisor task partitions input data into splits and assigns each of them to a single sub task.
- SplitStrategy - Interface in org.apache.druid.collections.spatial.split
- SplittableInputSource<T> - Interface in org.apache.druid.data.input.impl
-
Splittable InputSource.
- SPLITTER - Static variable in class org.apache.druid.frame.util.DurableStorageUtils
- splitToList(Splitter, String) - Static method in class org.apache.druid.data.input.impl.DelimitedInputFormat
-
Copied from Guava's
Splitter.splitToList(CharSequence)
. - splitVirtualColumns(VirtualColumns, List<VirtualColumn>, List<VirtualColumn>) - Method in class org.apache.druid.segment.join.filter.JoinableClauses
- SQL_JOIN_LEFT_SCAN_DIRECT - Static variable in class org.apache.druid.query.QueryContexts
- SQL_PARSE_FAILED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- SQL_QUERY_ID - Static variable in class org.apache.druid.query.BaseQuery
- SQL_QUERY_UNSUPPORTED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- sqlCompatible() - Static method in class org.apache.druid.common.config.NullHandling
- sqlQueryId(String) - Method in class org.apache.druid.query.DefaultQueryMetrics
- sqlQueryId(String) - Method in interface org.apache.druid.query.QueryMetrics
-
Sets sqlQueryId as a dimension
- sqlQueryId(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- sqlQueryId(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- 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 - sqrt(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Sqrt() - Constructor for class org.apache.druid.math.expr.Function.Sqrt
- sslContextWithTrustedKeyStore(String, String) - Static method in class org.apache.druid.java.util.http.client.HttpClientInit
- StableLimitingSorter<T> - Class in org.apache.druid.collections
-
Simultaneously sorts and limits its input.
- StableLimitingSorter(Comparator<T>, int) - Constructor for class org.apache.druid.collections.StableLimitingSorter
- stagedSerde - Variable in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnSerializer
- StagedSerde<T> - Interface in org.apache.druid.segment.serde.cell
-
StagedSerde
is useful when you have objects that have their own internal logic to serialize, but you wish to compose the results of multiple serialized objects into a single ByteBuffer (or wrappedbyte[]
). - standardRow() - Static method in class org.apache.druid.segment.RowAdapters
-
Returns a
RowAdapter
that handles any kind of inputRow
. - start - Variable in class org.apache.druid.timeline.partition.BaseDimensionRangeShardSpec
- start() - Method in class org.apache.druid.common.config.ConfigManager
- start() - Method in class org.apache.druid.common.config.Log4jShutdown
- start() - Method in class org.apache.druid.frame.allocation.MemoryRange
- start() - Method in interface org.apache.druid.java.util.common.lifecycle.Lifecycle.Handler
- start() - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
- start() - Method in class org.apache.druid.java.util.common.Stopwatch
- start() - Method in class org.apache.druid.java.util.emitter.core.ComposingEmitter
- start() - Method in interface org.apache.druid.java.util.emitter.core.Emitter
- start() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- start() - Method in class org.apache.druid.java.util.emitter.core.LoggingEmitter
- start() - Method in class org.apache.druid.java.util.emitter.core.NoopEmitter
- start() - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitter
- start() - Method in class org.apache.druid.java.util.emitter.core.SwitchingEmitter
-
Start the emitter.
- start() - Method in class org.apache.druid.java.util.emitter.service.ServiceEmitter
- start() - Method in class org.apache.druid.java.util.http.client.NettyHttpClient
- start() - Method in class org.apache.druid.java.util.metrics.AbstractMonitor
- start() - Method in class org.apache.druid.java.util.metrics.CompoundMonitor
- start() - Method in interface org.apache.druid.java.util.metrics.Monitor
- start() - Method in class org.apache.druid.java.util.metrics.MonitorScheduler
- start() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- 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
- start(long) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- START_TIME - Static variable in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- StartContext(ParserRuleContext, int) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.StartContext
- started() - Method in class org.apache.druid.concurrent.LifecycleLock
-
Announce the start was successful.
- startFileFromBeginning() - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- startFileFromBeginning() - Method in class org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser
- startFileFromBeginning() - Method in interface org.apache.druid.java.util.common.parsers.Parser
-
This method may or may not get called at the start of reading of every file depending on the type of IndexTasks.
- STARTING_FLAGS - Static variable in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde
- 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
- StartupInjectorBuilder - Class in org.apache.druid.guice
-
Create the startup injector used to "prime" the modules for the main injector.
- StartupInjectorBuilder() - Constructor for class org.apache.druid.guice.StartupInjectorBuilder
- stateString() - Method in class org.apache.druid.frame.processor.SuperSorter
-
Returns a string encapsulating the current state of this object.
- Stats(int, int, Integer) - Constructor for class org.apache.druid.indexer.report.KillTaskReport.Stats
- status(String) - Method in class org.apache.druid.query.DefaultQueryMetrics
- status(String) - Method in interface org.apache.druid.query.QueryMetrics
- status(String) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- STATUS - Static variable in class org.apache.druid.query.DruidMetrics
- STATUS_CODE - Static variable in exception org.apache.druid.query.QueryCapacityExceededException
- STATUS_CODE - Static variable in exception org.apache.druid.query.QueryTimeoutException
- STATUS_CODE - Static variable in exception org.apache.druid.query.QueryUnsupportedException
- StatusResponseHandler - Class in org.apache.druid.java.util.http.client.response
- StatusResponseHolder - Class in org.apache.druid.java.util.http.client.response
- StatusResponseHolder(HttpResponseStatus, StringBuilder) - Constructor for class org.apache.druid.java.util.http.client.response.StatusResponseHolder
- stop() - Method in class org.apache.druid.common.config.ConfigManager
- stop() - Method in class org.apache.druid.common.config.Log4jShutdown
- stop() - Method in class org.apache.druid.guice.LifecycleForkJoinPoolProvider
- stop() - Method in interface org.apache.druid.java.util.common.lifecycle.Lifecycle.Handler
- stop() - Method in class org.apache.druid.java.util.common.lifecycle.Lifecycle
- stop() - Method in class org.apache.druid.java.util.common.Stopwatch
- stop() - Method in class org.apache.druid.java.util.http.client.NettyHttpClient
- stop() - Method in class org.apache.druid.java.util.metrics.AbstractMonitor
- stop() - Method in class org.apache.druid.java.util.metrics.CompoundMonitor
- stop() - Method in interface org.apache.druid.java.util.metrics.Monitor
- stop() - Method in class org.apache.druid.java.util.metrics.MonitorScheduler
- stop() - Method in class org.apache.druid.java.util.metrics.ParametrizedUriEmitterMonitor
- stop() - Method in class org.apache.druid.segment.BaseProgressIndicator
- stop() - Method in interface org.apache.druid.segment.ProgressIndicator
- STOP - org.apache.druid.java.util.common.concurrent.ScheduledExecutors.Signal
- STOP - org.apache.druid.query.operator.Operator.Signal
-
Indicates that the downstream processing need not do anything else.
- 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
- Stopwatch - Class in org.apache.druid.java.util.common
-
Thread-safe wrapper over
Stopwatch
. - StorableBuffer - Interface in org.apache.druid.segment.serde.cell
-
It's useful to return this object when multiple serializable objects are to be composed into a single ByteBuffer or byte[].
- storageAdapter - Variable in class org.apache.druid.query.topn.BaseTopNAlgorithm
- StorageAdapter - Interface in org.apache.druid.segment
- StorageAdapterRowsAndColumns - Class in org.apache.druid.query.rowsandcols
-
Provides
RowsAndColumns
on top of aStorageAdapter
. - StorageAdapterRowsAndColumns(StorageAdapter) - Constructor for class org.apache.druid.query.rowsandcols.StorageAdapterRowsAndColumns
- StorageConfig - Class in org.apache.druid.storage
- StorageConfig(String) - Constructor for class org.apache.druid.storage.StorageConfig
- StorageConnector - Interface in org.apache.druid.storage
-
Low level interface for interacting with different storage providers like S3, GCS, Azure and local file system.
- StorageConnectorModule - Class in org.apache.druid.storage
- StorageConnectorModule() - Constructor for class org.apache.druid.storage.StorageConnectorModule
- StorageConnectorProvider - Interface in org.apache.druid.storage
- store(ByteBuffer) - Method in interface org.apache.druid.segment.serde.cell.StorableBuffer
- store(T) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectBufferStore
- store(T) - Method in class org.apache.druid.query.aggregation.SerializedStorage
- 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(SearchQuery) - Method in class org.apache.druid.query.search.SearchStrategySelector
- strategy - Variable in class org.apache.druid.segment.data.GenericIndexed
- stream() - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
- STREAM - Static variable in class org.apache.druid.query.DruidMetrics
- StreamingMergeSortedGrouper<KeyType> - Class in org.apache.druid.query.groupby.epinephelinae
-
A streaming grouper which can aggregate sorted inputs.
- Streams - Class in org.apache.druid.utils
- streamTaskLog(String, long) - Method in class org.apache.druid.tasklogs.NoopTaskLogs
- streamTaskLog(String, long) - Method in interface org.apache.druid.tasklogs.TaskLogStreamer
-
Stream log for a task.
- streamTaskPayload(String) - Method in class org.apache.druid.tasklogs.NoopTaskLogs
- streamTaskPayload(String) - Method in interface org.apache.druid.tasklogs.TaskPayloadManager
-
Stream payload for a task.
- streamTaskReports(String) - Method in interface org.apache.druid.tasklogs.TaskLogStreamer
- streamTaskStatus(String) - Method in interface org.apache.druid.tasklogs.TaskLogStreamer
- StreamUtils - Class in org.apache.druid.java.util.common
- StreamUtils() - Constructor for class org.apache.druid.java.util.common.StreamUtils
- STRICT - org.apache.druid.query.metadata.metadata.AggregatorMergeStrategy
- STRING - org.apache.druid.math.expr.ExprType
- STRING - org.apache.druid.segment.column.ValueType
-
String object type.
- STRING - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- STRING - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- STRING - Static variable in class org.apache.druid.math.expr.ExpressionType
- STRING - Static variable in class org.apache.druid.segment.column.ColumnType
-
Druid string type.
- STRING - Static variable in class org.apache.druid.segment.column.TypeStrategies
- STRING() - Method in class org.apache.druid.math.expr.antlr.ExprParser.LiteralElementContext
- STRING() - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringContext
- STRING() - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringElementContext
- STRING_ANY_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- STRING_ARRAY - Static variable in class org.apache.druid.math.expr.ExpressionType
- STRING_ARRAY - Static variable in class org.apache.druid.segment.column.ColumnType
-
An array of Strings.
- STRING_DICTIONARY_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- STRING_DICTIONARY_FILE_NAME - Static variable in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- STRING_FIRST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- STRING_INTERNER - Static variable in class org.apache.druid.java.util.common.io.smoosh.SmooshedFileMapper
-
Interner for smoosh internal files, which includes all column names since every column has an internal file associated with it
- STRING_LAST_CACHE_TYPE_ID - Static variable in class org.apache.druid.query.aggregation.AggregatorUtil
- STRING_MERGING_COMPARATOR - Static variable in class org.apache.druid.segment.AutoTypeColumnMerger
- STRING_MERGING_COMPARATOR - Static variable in class org.apache.druid.segment.NestedDataColumnMergerV4
- 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
- STRING_TYPE_NAME - Static variable in class org.apache.druid.data.input.impl.DimensionSchema
- StringAnyAggregator - Class in org.apache.druid.query.aggregation.any
- StringAnyAggregator(BaseObjectColumnValueSelector, int, boolean) - Constructor for class org.apache.druid.query.aggregation.any.StringAnyAggregator
- StringAnyAggregatorFactory - Class in org.apache.druid.query.aggregation.any
- StringAnyAggregatorFactory(String, String, Integer, Boolean) - Constructor for class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
- StringAnyBufferAggregator - Class in org.apache.druid.query.aggregation.any
- StringAnyBufferAggregator(BaseObjectColumnValueSelector, int, boolean) - Constructor for class org.apache.druid.query.aggregation.any.StringAnyBufferAggregator
- StringAnyVectorAggregator - Class in org.apache.druid.query.aggregation.any
- StringAnyVectorAggregator(SingleValueDimensionVectorSelector, MultiValueDimensionVectorSelector, int, boolean) - Constructor for class org.apache.druid.query.aggregation.any.StringAnyVectorAggregator
- StringArrayContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.StringArrayContext
- StringArrayFieldReader - Class in org.apache.druid.frame.field
-
Reads fields written by
StringArrayFieldWriter
- StringArrayFieldWriter - Class in org.apache.druid.frame.field
-
Like
StringFieldWriter
, but reads arrays from aColumnValueSelector
instead of reading from aDimensionSelector
. - StringArrayFieldWriter(BaseObjectColumnValueSelector<?>) - Constructor for class org.apache.druid.frame.field.StringArrayFieldWriter
- 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
-
Comparison using the natural comparator of
String
. - StringComparators.NaturalComparator - Class in org.apache.druid.query.ordering
-
NaturalComparator refers to the natural ordering of the type that it refers.
- 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
- StringConstantValueMatcherFactory - Class in org.apache.druid.segment.filter
-
Creates
ValueMatcher
that match constants. - StringContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.StringContext
- StringDecodeBase64UTFExprMacro() - Constructor for class org.apache.druid.math.expr.BuiltInExprMacros.StringDecodeBase64UTFExprMacro
- StringDimensionDictionary - Class in org.apache.druid.segment
-
DimensionDictionary for String dimension values.
- StringDimensionDictionary(boolean) - Constructor for class org.apache.druid.segment.StringDimensionDictionary
-
Creates a StringDimensionDictionary.
- 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, 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.SpatialIndexesMerger - Class in org.apache.druid.segment
-
Write spatial indexes for string columns that have them
- StringDimensionSchema - Class in org.apache.druid.data.input.impl
- StringDimensionSchema(String) - Constructor for class org.apache.druid.data.input.impl.StringDimensionSchema
- StringDimensionSchema(String, DimensionSchema.MultiValueHandling, Boolean) - Constructor for class org.apache.druid.data.input.impl.StringDimensionSchema
- stringElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringArrayContext
- stringElement() - Method in class org.apache.druid.math.expr.antlr.ExprParser
- stringElement(int) - Method in class org.apache.druid.math.expr.antlr.ExprParser.StringArrayContext
- StringElementContext(ParserRuleContext, int) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.StringElementContext
- StringEncoding - Enum in org.apache.druid.java.util.common
-
An enum that provides a way for users to specify what encoding should be used when hashing strings.
- StringEncodingDefaultUTF16LEJsonIncludeFilter - Class in org.apache.druid.java.util.common
-
JsonInclude
filter forStringEncoding
that ignores UTF16LE, which is the typical default for aggregators. - StringEncodingDefaultUTF16LEJsonIncludeFilter() - Constructor for class org.apache.druid.java.util.common.StringEncodingDefaultUTF16LEJsonIncludeFilter
- StringEncodingStrategies - Class in org.apache.druid.segment.column
- StringEncodingStrategies() - Constructor for class org.apache.druid.segment.column.StringEncodingStrategies
- StringEncodingStrategies.Utf8ToStringIndexed - Class in org.apache.druid.segment.column
- StringEncodingStrategy - Interface in org.apache.druid.segment.column
- StringEncodingStrategy.FrontCoded - Class in org.apache.druid.segment.column
- StringEncodingStrategy.Utf8 - Class in org.apache.druid.segment.column
- StringFieldReader - Class in org.apache.druid.frame.field
-
Reads fields written by
StringFieldWriter
orStringArrayFieldWriter
. - StringFieldReader() - Constructor for class org.apache.druid.frame.field.StringFieldReader
- StringFieldReader(boolean) - Constructor for class org.apache.druid.frame.field.StringFieldReader
-
Create a string reader.
- StringFieldWriter - Class in org.apache.druid.frame.field
-
Wraps a
DimensionSelector
and writes to rframe rows. - StringFieldWriter(DimensionSelector) - Constructor for class org.apache.druid.frame.field.StringFieldWriter
- StringFirstAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- StringFirstAggregator(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>, int, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregator
- StringFirstAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.first
- StringFirstAggregatorFactory(String, String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- StringFirstBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- StringFirstBufferAggregator(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>, int, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.StringFirstBufferAggregator
- StringFirstFoldingAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.first
-
For backwards compatibility; equivalent to a regular StringFirstAggregatorFactory.
- StringFirstFoldingAggregatorFactory(String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.StringFirstFoldingAggregatorFactory
- StringFirstLastUtils - Class in org.apache.druid.query.aggregation.firstlast
- StringFirstLastUtils() - Constructor for class org.apache.druid.query.aggregation.firstlast.StringFirstLastUtils
- StringFirstLastVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast
- StringFirstLastVectorAggregator(VectorValueSelector, VectorObjectSelector, int, SelectionPredicate) - Constructor for class org.apache.druid.query.aggregation.firstlast.StringFirstLastVectorAggregator
- StringFirstVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.first
- StringFirstVectorAggregator(VectorValueSelector, VectorObjectSelector, int) - Constructor for class org.apache.druid.query.aggregation.firstlast.first.StringFirstVectorAggregator
- StringFormatExtractionFn - Class in org.apache.druid.query.extraction
- StringFormatExtractionFn(String) - Constructor for class org.apache.druid.query.extraction.StringFormatExtractionFn
- StringFormatExtractionFn(String, StringFormatExtractionFn.NullHandling) - Constructor for class org.apache.druid.query.extraction.StringFormatExtractionFn
- StringFormatExtractionFn.NullHandling - Enum in org.apache.druid.query.extraction
- StringFormatFunc() - Constructor for class org.apache.druid.math.expr.Function.StringFormatFunc
- StringFrameColumnReader - Class in org.apache.druid.frame.read.columnar
- StringFrameColumnWriter<T extends ColumnValueSelector> - Class in org.apache.druid.frame.write.columnar
- StringFullResponseHandler - Class in org.apache.druid.java.util.http.client.response
-
HttpResponseHandler
for stream data of string type. - StringFullResponseHandler(Charset) - Constructor for class org.apache.druid.java.util.http.client.response.StringFullResponseHandler
- StringFullResponseHolder - Class in org.apache.druid.java.util.http.client.response
- StringFullResponseHolder(HttpResponse, Charset) - Constructor for class org.apache.druid.java.util.http.client.response.StringFullResponseHolder
- stringify() - Method in interface org.apache.druid.math.expr.Expr
-
Convert the
Expr
back into parseable string that when parsed withParser.parse(String, ExprMacroTable)
will produce an equivalentExpr
. - stringify() - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- StringInputRowParser - Class in org.apache.druid.data.input.impl
- StringInputRowParser(ParseSpec) - Constructor for class org.apache.druid.data.input.impl.StringInputRowParser
-
Deprecated.
- StringInputRowParser(ParseSpec, String) - Constructor for class org.apache.druid.data.input.impl.StringInputRowParser
- StringLastAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- StringLastAggregator(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>, int, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregator
- StringLastAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.last
- StringLastAggregatorFactory(String, String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- StringLastBufferAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- StringLastBufferAggregator(BaseLongColumnValueSelector, BaseObjectColumnValueSelector<?>, int, boolean) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.StringLastBufferAggregator
- StringLastFoldingAggregatorFactory - Class in org.apache.druid.query.aggregation.firstlast.last
-
For backwards compatibility; equivalent to a regular StringLastAggregatorFactory.
- StringLastFoldingAggregatorFactory(String, String, Integer) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.StringLastFoldingAggregatorFactory
- StringLastVectorAggregator - Class in org.apache.druid.query.aggregation.firstlast.last
- StringLastVectorAggregator(VectorValueSelector, VectorObjectSelector, int) - Constructor for class org.apache.druid.query.aggregation.firstlast.last.StringLastVectorAggregator
- StringLongFunction() - Constructor for class org.apache.druid.math.expr.Function.StringLongFunction
- StringMultiValueDimensionVectorSelector(ColumnarMultiInts, ReadableVectorOffset) - Constructor for class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringMultiValueDimensionVectorSelector
- StringObjectCardinalityVectorProcessor - Class in org.apache.druid.query.aggregation.cardinality.vector
- StringObjectCardinalityVectorProcessor(VectorObjectSelector) - Constructor for class org.apache.druid.query.aggregation.cardinality.vector.StringObjectCardinalityVectorProcessor
- StringObjectVectorValueMatcher - Class in org.apache.druid.query.filter.vector
-
String matcher on top of a
VectorObjectSelector
- StringObjectVectorValueMatcher(VectorObjectSelector) - Constructor for class org.apache.druid.query.filter.vector.StringObjectVectorValueMatcher
- StringPartitionChunk<T> - Class in org.apache.druid.timeline.partition
- StringPredicateDruidPredicateFactory - Class in org.apache.druid.query.filter
- StringRuntimeShape - Class in org.apache.druid.query.monomorphicprocessing
-
Class to be used to obtain String representation of runtime shape of one or several
HotLoopCallee
s. - Strings(InputStream) - Constructor for class org.apache.druid.data.input.impl.FastLineIterator.Strings
- Strings(InputRowSchema, InputEntity) - Constructor for class org.apache.druid.data.input.TextReader.Strings
- StringSearchColumnSelectorStrategy() - Constructor for class org.apache.druid.query.search.SearchQueryRunner.StringSearchColumnSelectorStrategy
- StringSingleValueDimensionVectorSelector(ColumnarInts, ReadableVectorOffset) - Constructor for class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringSingleValueDimensionVectorSelector
- StringToArrayFunction() - Constructor for class org.apache.druid.math.expr.Function.StringToArrayFunction
- StringTopNColumnAggregatesProcessor - Class in org.apache.druid.query.topn.types
- StringTopNColumnAggregatesProcessor(ColumnCapabilities, ColumnType) - Constructor for class org.apache.druid.query.topn.types.StringTopNColumnAggregatesProcessor
- StringTuple - Class in org.apache.druid.data.input
-
Represents a tuple of String values, typically used to represent (single-valued) dimension values for an InputRow.
- StringTuple(String[]) - Constructor for class org.apache.druid.data.input.StringTuple
- StringTypeStrategy() - Constructor for class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- StringUtf8ColumnIndexSupplier<TIndexed extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.serde
- StringUtf8ColumnIndexSupplier(BitmapFactory, Supplier<TIndexed>, GenericIndexed<ImmutableBitmap>, ImmutableRTree) - Constructor for class org.apache.druid.segment.serde.StringUtf8ColumnIndexSupplier
- StringUtf8DictionaryEncodedColumn - Class in org.apache.druid.segment.column
-
DictionaryEncodedColumn
for a column which has aByteBuffer
based UTF-8 dictionary. - StringUtf8DictionaryEncodedColumn(ColumnarInts, ColumnarMultiInts, Indexed<ByteBuffer>) - Constructor for class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn
- StringUtf8DictionaryEncodedColumn.MultiValueStringVectorObjectSelector - Class in org.apache.druid.segment.column
-
Base type for a
VectorObjectSelector
for a dictionary encodedColumnType.STRING
built around aColumnarMultiInts
. - StringUtf8DictionaryEncodedColumn.StringMultiValueDimensionVectorSelector - Class in org.apache.druid.segment.column
-
Base type for a
MultiValueDimensionVectorSelector
for a dictionary encodedColumnType.STRING
built around aColumnarMultiInts
. - StringUtf8DictionaryEncodedColumn.StringSingleValueDimensionVectorSelector - Class in org.apache.druid.segment.column
-
Base type for a
SingleValueDimensionVectorSelector
for a dictionary encodedColumnType.STRING
built around aColumnarInts
. - StringUtf8DictionaryEncodedColumn.StringVectorObjectSelector - Class in org.apache.druid.segment.column
-
Base type for a
VectorObjectSelector
for a dictionary encodedColumnType.STRING
built around aColumnarInts
. - StringUtf8DictionaryEncodedColumnSupplier<TIndexed extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.serde
-
Supplier for
StringUtf8DictionaryEncodedColumn
- StringUtf8DictionaryEncodedColumnSupplier(Supplier<TIndexed>, Supplier<ColumnarInts>, Supplier<ColumnarMultiInts>) - Constructor for class org.apache.druid.segment.serde.StringUtf8DictionaryEncodedColumnSupplier
- StringUtils - Class in org.apache.druid.java.util.common
-
As of OpenJDK / Oracle JDK 8, the JVM is optimized around String charset variable instead of Charset passing, that is exploited in
StringUtils.toUtf8(String)
andStringUtils.fromUtf8(byte[])
. - StringUtils() - Constructor for class org.apache.druid.java.util.common.StringUtils
- StringValueSetIndexes - Interface in org.apache.druid.segment.index.semantic
-
Deprecated.
- StringVectorObjectSelector(ColumnarInts, ReadableVectorOffset) - Constructor for class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringVectorObjectSelector
- stripQuotes(String) - Static method in class org.apache.druid.java.util.common.parsers.ParserUtils
- 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
- StrlenFunc() - Constructor for class org.apache.druid.math.expr.Function.StrlenFunc
- StrposFunc() - Constructor for class org.apache.druid.math.expr.Function.StrposFunc
- StructuredData - Class in org.apache.druid.segment.nested
- StructuredData(Object) - Constructor for class org.apache.druid.segment.nested.StructuredData
- StructuredDataJsonSerializer - Class in org.apache.druid.segment.nested
- StructuredDataJsonSerializer() - Constructor for class org.apache.druid.segment.nested.StructuredDataJsonSerializer
- StructuredDataProcessor - Class in org.apache.druid.segment.nested
- StructuredDataProcessor() - Constructor for class org.apache.druid.segment.nested.StructuredDataProcessor
- StructuredDataProcessor.ProcessedValue<T> - Class in org.apache.druid.segment.nested
- StructuredDataProcessor.ProcessResults - Class in org.apache.druid.segment.nested
-
Accumulates the list of literal field paths and a rough size estimation for
StructuredDataProcessor
- StupidPool<T> - Class in org.apache.druid.collections
- StupidPool(String, Supplier<T>) - Constructor for class org.apache.druid.collections.StupidPool
- StupidPool(String, Supplier<T>, int, int) - Constructor for class org.apache.druid.collections.StupidPool
- StupidResourceHolder<T> - Class in org.apache.druid.collections
- StupidResourceHolder(T) - Constructor for class org.apache.druid.collections.StupidResourceHolder
- SUB_QUERY_ID - Static variable in class org.apache.druid.query.BaseQuery
- SubclassesMustBePublic - Annotation Type in org.apache.druid.annotations
- SubclassesMustBePublicAnnotationProcessor - Class in org.apache.druid.annotations
- SubclassesMustBePublicAnnotationProcessor() - Constructor for class org.apache.druid.annotations.SubclassesMustBePublicAnnotationProcessor
- SubclassesMustOverrideEqualsAndHashCode - Annotation Type in org.apache.druid.annotations
-
An annotation that tells all subclasses of the annotated class to not use the default implementation of hashCode and equals that is provided by
Object
. - 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
- submitRunnerTask(PrioritizedQueryRunnerCallable<T, V>) - Method in class org.apache.druid.query.DirectQueryProcessingPool
- submitRunnerTask(PrioritizedQueryRunnerCallable<T, V>) - Method in class org.apache.druid.query.ForwardingQueryProcessingPool
- submitRunnerTask(PrioritizedQueryRunnerCallable<T, V>) - Method in interface org.apache.druid.query.QueryProcessingPool
-
Submits the query execution unit task for asynchronous execution.
- SubMonthFunc() - Constructor for class org.apache.druid.math.expr.Function.SubMonthFunc
- subMonths(long, long, DateTimeZone) - Static method in class org.apache.druid.java.util.common.DateTimes
- SUBQUERY_ROW_TOO_LARGE_EXCEPTION - Static variable in class org.apache.druid.frame.segment.FrameCursorUtils
-
Exception to be thrown when the subquery's rows are too wide to fit in a single frame.
- subQueryId(SearchQuery) - Method in class org.apache.druid.query.search.DefaultSearchQueryMetrics
- 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. - 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
- subSet(int, int) - Method in class org.apache.druid.collections.RangeIntSet
- SubstringDimExtractionFn - Class in org.apache.druid.query.extraction
- SubstringDimExtractionFn(int, Integer) - Constructor for class org.apache.druid.query.extraction.SubstringDimExtractionFn
- SubstringFunc() - Constructor for class org.apache.druid.math.expr.Function.SubstringFunc
- subtract(Map<String, Long>, Map<String, Long>) - Static method in class org.apache.druid.java.util.metrics.KeyedDiff
- subtract(Set<T>, Set<T>) - Static method in class org.apache.druid.utils.CollectionUtils
-
Subtract one set from another:
C = A - B
. - 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
- success(String) - Static method in class org.apache.druid.indexer.TaskStatus
- success(String, String) - Static method in class org.apache.druid.indexer.TaskStatus
-
Deprecated.
- success(String, TaskLocation) - Static method in class org.apache.druid.indexer.TaskStatus
- SUCCESS - org.apache.druid.indexer.TaskState
- SUCCESS_MARKER_FILENAME - Static variable in class org.apache.druid.frame.util.DurableStorageUtils
- SuperSorter - Class in org.apache.druid.frame.processor
-
Sorts and partitions a dataset using parallel external merge sort.
- SuperSorter(List<ReadableFrameChannel>, FrameReader, List<KeyColumn>, ListenableFuture<ClusterByPartitions>, FrameProcessorExecutor, OutputChannelFactory, OutputChannelFactory, int, int, long, String, SuperSorterProgressTracker) - Constructor for class org.apache.druid.frame.processor.SuperSorter
-
Initializes a SuperSorter.
- SuperSorterProgressSnapshot - Class in org.apache.druid.frame.processor
-
Like
SuperSorterProgressTracker
, but immutable. - SuperSorterProgressSnapshot(int, Map<Integer, Long>, Map<Integer, Long>, long, boolean) - Constructor for class org.apache.druid.frame.processor.SuperSorterProgressSnapshot
- SuperSorterProgressTracker - Class in org.apache.druid.frame.processor
-
A thread-safe class that keeps track of the progress of an n-way, multilevel merge sort.
- SuperSorterProgressTracker() - Constructor for class org.apache.druid.frame.processor.SuperSorterProgressTracker
- supplyAnalyzeInputs() - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
-
Implemented by subclasses to provide the value for
ExprMacroTable.BaseMacroFunctionExpr.analyzeInputs()
, which uses a memoized supplier. - supplyAnalyzeInputs() - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseScalarMacroFunctionExpr
- SUPPORTED_SIZES - Static variable in class org.apache.druid.segment.data.VSizeLongSerde
- supportsAsMap() - Method in class org.apache.druid.query.extraction.MapLookupExtractor
- supportsAsMap() - Method in class org.apache.druid.query.lookup.ImmutableLookupMap.ImmutableLookupExtractor
- supportsAsMap() - Method in class org.apache.druid.query.lookup.LookupExtractor
-
Returns whether this lookup extractor's
LookupExtractor.asMap()
will return a valid map. - supportsComplexTypes() - Method in class org.apache.druid.query.aggregation.cardinality.types.CardinalityAggregatorColumnSelectorStrategyFactory
- supportsComplexTypes() - Method in interface org.apache.druid.query.dimension.ColumnSelectorStrategyFactory
-
Whether the strategy supports complex types.
- supportsComplexTypes() - Method in class org.apache.druid.query.groupby.epinephelinae.GroupByColumnSelectorStrategyFactory
- supportsComplexTypes() - Method in class org.apache.druid.query.topn.types.TopNColumnAggregatesProcessorFactory
- supportsLookupNameUtf8() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringMultiValueDimensionVectorSelector
- supportsLookupNameUtf8() - Method in class org.apache.druid.segment.column.StringUtf8DictionaryEncodedColumn.StringSingleValueDimensionVectorSelector
- supportsLookupNameUtf8() - Method in interface org.apache.druid.segment.DimensionDictionarySelector
-
Returns whether this selector supports
DimensionDictionarySelector.lookupNameUtf8(int)
. - supportsPushDown() - Method in class org.apache.druid.segment.join.filter.JoinFilterColumnCorrelationAnalysis
- supportsRequiredColumnRewrite() - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- supportsRequiredColumnRewrite() - Method in class org.apache.druid.query.filter.EqualityFilter
- 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.query.filter.NullFilter
- supportsRequiredColumnRewrite() - Method in class org.apache.druid.query.filter.RangeFilter
- supportsRequiredColumnRewrite() - Method in class org.apache.druid.query.filter.TypedInFilter
- supportsRequiredColumnRewrite() - Method in class org.apache.druid.segment.filter.AndFilter
- 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.IsBooleanFilter
- 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.OrFilter
- 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
- 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
- SuppressFBWarnings - Annotation Type in org.apache.druid.annotations
-
Annotation for suppressing spotbugs checks when necessary.
- swapValues(int, int) - Method in interface org.apache.druid.query.rowsandcols.column.ColumnValueSwapper
-
Swaps the values at the two row ids.
- SwitchingEmitter - Class in org.apache.druid.java.util.emitter.core
-
An emitter than that offers the ability to direct an event to multiple emitters based on the event's feed.
- SwitchingEmitter(Map<String, List<Emitter>>, Emitter[]) - Constructor for class org.apache.druid.java.util.emitter.core.SwitchingEmitter
-
Constructor for the SwitchingEmitter
- SymmetricalBivariateFunctionVectorProcessor<T> - Class in org.apache.druid.math.expr.vector
- SymmetricalBivariateFunctionVectorProcessor(ExpressionType, ExprVectorProcessor<T>, ExprVectorProcessor<T>) - Constructor for class org.apache.druid.math.expr.vector.SymmetricalBivariateFunctionVectorProcessor
- SYNC - org.apache.druid.query.ExecutionMode
-
This mode executes the query in a blocking way.
- SysMonitor - Class in org.apache.druid.java.util.metrics
-
Deprecated.
- SysMonitor() - Constructor for class org.apache.druid.java.util.metrics.SysMonitor
-
Deprecated.
- SysMonitor(Map<String, String[]>) - Constructor for class org.apache.druid.java.util.metrics.SysMonitor
-
Deprecated.
- SysMonitor(Map<String, String[]>, String) - Constructor for class org.apache.druid.java.util.metrics.SysMonitor
-
Deprecated.
- SYSTEM_FIELDS_PROPERTY - Static variable in interface org.apache.druid.data.input.impl.systemfield.SystemFieldInputSource
- systemClassPath() - Static method in class org.apache.druid.utils.JvmUtils
- SystemField - Enum in org.apache.druid.data.input.impl.systemfield
-
System fields that can appear when reading data.
- SystemFieldDecoratorFactory - Class in org.apache.druid.data.input.impl.systemfield
-
Decorator of
InputRow
from anInputEntity
. - SystemFieldInputSource - Interface in org.apache.druid.data.input.impl.systemfield
-
An
InputSource
that can generate system fields. - systemFields - Variable in class org.apache.druid.data.input.impl.CloudObjectInputSource
- SystemFields - Class in org.apache.druid.data.input.impl.systemfield
-
Container of
SystemField
. - SystemFields(EnumSet<SystemField>) - Constructor for class org.apache.druid.data.input.impl.systemfield.SystemFields
- sysTime() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
- sysTime(int) - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
- sysTimes() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
T
- T__0 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__0 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- T__1 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__1 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- T__2 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__2 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- T__3 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__3 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- T__4 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__4 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- T__5 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__5 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- T__6 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__6 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- T__7 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__7 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- T__8 - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- T__8 - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- TABLE - org.apache.druid.segment.data.CompressionFactory.LongEncodingFormat
-
TABLE format encodes a series of longs by mapping each unique value to an id, and string the id with the minimum number of bits similar to how DELTA stores offset.
- 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
- TAGS - Static variable in class org.apache.druid.query.DruidMetrics
- tailSet(int) - Method in class org.apache.druid.collections.RangeIntSet
- take() - Method in class org.apache.druid.collections.DummyNonBlockingPool
- take() - Method in interface org.apache.druid.collections.NonBlockingPool
- take() - Method in class org.apache.druid.collections.StupidPool
- take() - Method in class org.apache.druid.java.util.common.MemoryBoundLinkedBlockingQueue
- take(K) - Method in class org.apache.druid.java.util.http.client.pool.ResourcePool
-
Returns a
ResourceContainer
for the given key or null if this pool is already closed. - takeBatch(int) - Method in interface org.apache.druid.collections.BlockingPool
-
Take resources from the pool, waiting if necessary until the elements of the given number become available.
- takeBatch(int) - Method in class org.apache.druid.collections.DefaultBlockingPool
- takeBatch(int) - Method in class org.apache.druid.collections.DummyBlockingPool
- takeBatch(int, long) - Method in interface org.apache.druid.collections.BlockingPool
-
Take resources from the pool, waiting up to the specified wait time if necessary for elements of the given number to become available.
- takeBatch(int, long) - Method in class org.apache.druid.collections.DefaultBlockingPool
- takeBatch(int, long) - Method in class org.apache.druid.collections.DummyBlockingPool
- takeSnapshot(String, List<LookupBean>) - Method in class org.apache.druid.query.lookup.LookupSnapshotTaker
- tan(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Tan() - Constructor for class org.apache.druid.math.expr.Function.Tan
- tanh(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Tanh() - Constructor for class org.apache.druid.math.expr.Function.Tanh
- TARGET_PARTITION_SIZE - Static variable in interface org.apache.druid.indexer.partitions.DimensionBasedPartitionsSpec
-
Deprecated.
- TARGET_ROWS_PER_SEGMENT - Static variable in interface org.apache.druid.indexer.partitions.DimensionBasedPartitionsSpec
- TASK_ENTRY_TYPE - Static variable in class org.apache.druid.metadata.MetadataStorageTablesConfig
- TASK_ID - Static variable in class org.apache.druid.query.DruidMetrics
- TASK_INGESTION_MODE - 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
- TaskContextReport - Class in org.apache.druid.indexer.report
- TaskContextReport(String, Map<String, Object>) - Constructor for class org.apache.druid.indexer.report.TaskContextReport
- TaskIdentifier - Class in org.apache.druid.indexer
-
Model class containing the id, type and groupId of a task These fields are extracted from the task payload for the new schema and this model can be used for migration as well.
- TaskIdentifier(String, String, String) - Constructor for class org.apache.druid.indexer.TaskIdentifier
- TaskInfo<EntryType,StatusType> - Class in org.apache.druid.indexer
-
This class is used to store task info from runner query and cache in OverlordResource
- TaskInfo(String, DateTime, StatusType, String, EntryType) - Constructor for class org.apache.druid.indexer.TaskInfo
- TaskLocation - Class in org.apache.druid.indexer
- TaskLocation(String, int, int, String) - Constructor for class org.apache.druid.indexer.TaskLocation
- TaskLogKiller - Interface in org.apache.druid.tasklogs
-
Cleans up stale task logs from deep storage.
- TaskLogPusher - Interface in org.apache.druid.tasklogs
-
Something that knows how to persist local task logs to some form of long-term storage.
- TaskLogs - Interface in org.apache.druid.tasklogs
- taskLogsBinder(Binder) - Static method in class org.apache.druid.guice.Binders
- TaskLogStreamer - Interface in org.apache.druid.tasklogs
-
Something that knows how to stream logs for tasks.
- TaskLookup - Interface in org.apache.druid.metadata
-
Lookup types and parameters for task lookups in the metadata store.
- TaskLookup.ActiveTaskLookup - Class in org.apache.druid.metadata
- TaskLookup.CompleteTaskLookup - Class in org.apache.druid.metadata
-
Task lookup for complete tasks.
- TaskLookup.TaskLookupType - Enum in org.apache.druid.metadata
-
Task state in the metadata store.
- TaskMetricsGetter - Interface in org.apache.druid.indexer
- TaskMetricsUtils - Class in org.apache.druid.indexer
- TaskMetricsUtils() - Constructor for class org.apache.druid.indexer.TaskMetricsUtils
- TaskPayloadManager - Interface in org.apache.druid.tasklogs
-
Something that knows how to push a task payload before it is run to somewhere a ingestion worker will be able to stream the task payload from when trying to run the task.
- TaskReport - Interface in org.apache.druid.indexer.report
-
TaskReport objects contain additional information about an indexing task, such as row statistics, errors, and published segments.
- TaskReport.ReportMap - Class in org.apache.druid.indexer.report
-
Represents an ordered map from report key to a TaskReport that is compatible for writing out reports to files or serving over HTTP.
- TaskReportFileWriter - Interface in org.apache.druid.indexer.report
- TaskState - Enum in org.apache.druid.indexer
- TaskStatus - Class in org.apache.druid.indexer
-
Represents the status of a task from the perspective of the coordinator.
- TaskStatus(String, TaskState, long, String, TaskLocation) - Constructor for class org.apache.druid.indexer.TaskStatus
- TaskStatusPlus - Class in org.apache.druid.indexer
- TaskStatusPlus(String, String, String, DateTime, DateTime, TaskState, RunnerTaskState, Long, TaskLocation, String, String) - Constructor for class org.apache.druid.indexer.TaskStatusPlus
- TaskStatusPlus(String, String, String, DateTime, DateTime, TaskState, TaskState, RunnerTaskState, Long, TaskLocation, String, String) - Constructor for class org.apache.druid.indexer.TaskStatusPlus
- TaskThreadPriority - Class in org.apache.druid.concurrent
- TaskThreadPriority() - Constructor for class org.apache.druid.concurrent.TaskThreadPriority
- 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
- tempDirSupplier(Supplier<File>) - Method in class org.apache.druid.storage.remote.ChunkingStorageConnectorParameters.Builder
- TemporaryStorageFullException - Exception in org.apache.druid.query.groupby.epinephelinae
- TemporaryStorageFullException(long) - Constructor for exception org.apache.druid.query.groupby.epinephelinae.TemporaryStorageFullException
- TEN_MINUTE - org.apache.druid.java.util.common.granularity.GranularityType
- TEN_MINUTE - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- TEST_FLUSH_TIMEOUT_MILLIS - Static variable in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- TextReader<T> - Class in org.apache.druid.data.input
-
Abstract
InputEntityReader
for text format readers such as CSV or JSON. - TextReader(InputRowSchema, InputEntity) - Constructor for class org.apache.druid.data.input.TextReader
- TextReader.Bytes - Class in org.apache.druid.data.input
- TextReader.Strings - Class in org.apache.druid.data.input
- 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
- theUnsafe() - Static method in class org.apache.druid.java.util.common.UnsafeUtils
- theUnsafeClass() - Static method in class org.apache.druid.java.util.common.UnsafeUtils
- third - Variable in class org.apache.druid.java.util.common.Triple
- THIRTY_MINUTE - org.apache.druid.java.util.common.granularity.GranularityType
- THIRTY_MINUTE - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- ThreadRenamingCallable<T> - Class in org.apache.druid.common.guava
- ThreadRenamingCallable(String) - Constructor for class org.apache.druid.common.guava.ThreadRenamingCallable
- ThreadRenamingRunnable - Class in org.apache.druid.common.guava
- ThreadRenamingRunnable(String) - Constructor for class org.apache.druid.common.guava.ThreadRenamingRunnable
- Threads - Class in org.apache.druid.concurrent
- THREE_VALUE_LOGIC_CONFIG_STRING - Static variable in class org.apache.druid.common.config.NullValueHandlingConfig
- threshold(int) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- threshold(TopNQuery) - Method in class org.apache.druid.query.topn.DefaultTopNQueryMetrics
- threshold(TopNQuery) - Method in interface org.apache.druid.query.topn.TopNQueryMetrics
-
Sets
TopNQuery.getThreshold()
of the given query as dimension. - Throwables - Class in org.apache.druid.utils
- throwIfInvalidProtocols(HttpInputSourceConfig, List<URI>) - Static method in class org.apache.druid.data.input.impl.HttpInputSource
- throwIfPropertiesAreNotAllowed(Set<String>, Set<String>, Set<String>) - Static method in class org.apache.druid.utils.ConnectionUriUtils
-
This method checks {@param actualProperties} against {@param allowedProperties} if they are not system properties.
- THROWN_AWAY - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
- ticket() - Method in class org.apache.druid.frame.processor.Bouncer
- Ticket() - Constructor for class org.apache.druid.frame.processor.Bouncer.Ticket
- time() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
- TIME_BOUNDARY - Static variable in interface org.apache.druid.query.Query
- TIME_BOUNDARY_PLANNING_KEY - Static variable in class org.apache.druid.query.QueryContexts
- TIME_COLUMN_NAME - Static variable in interface org.apache.druid.segment.column.ColumnHolder
- TIME_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- TimeAndDimsIterator - Interface in org.apache.druid.segment
-
TimeAndDimsIterator (in conjunction with
TimeAndDimsPointer
) is anIterator
-like abstraction, designed for allocation-free transformation, merging, combining and iteration over a stream of data points. - TimeAndDimsParseSpec - Class in org.apache.druid.data.input.impl
- TimeAndDimsParseSpec(TimestampSpec, DimensionsSpec) - Constructor for class org.apache.druid.data.input.impl.TimeAndDimsParseSpec
- 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, asTimeAndDimsIterator.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
- TimedShutoffInputSourceReader - Class in org.apache.druid.data.input.impl
- TimedShutoffInputSourceReader(InputSourceReader, DateTime) - Constructor for class org.apache.druid.data.input.impl.TimedShutoffInputSourceReader
- 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
- TimelineLookup<VersionType,ObjectType extends Overshadowable<ObjectType>> - Interface in org.apache.druid.timeline
- TimelineObjectHolder<VersionType,ObjectType extends Overshadowable<ObjectType>> - Class in org.apache.druid.timeline
- TimelineObjectHolder(Interval, Interval, VersionType, PartitionHolder<ObjectType>) - Constructor for class org.apache.druid.timeline.TimelineObjectHolder
- TimelineObjectHolder(Interval, VersionType, PartitionHolder<ObjectType>) - Constructor for class org.apache.druid.timeline.TimelineObjectHolder
- TIMEOUT - org.apache.druid.error.DruidException.Category
-
A timeout happened
- TIMEOUT - org.apache.druid.query.QueryException.FailType
- TIMEOUT_AT - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
This variable indicates when a running query should be expired, and is effective only when 'timeout' of queryContext has a positive value.
- TIMEOUT_KEY - Static variable in class org.apache.druid.query.QueryContexts
- timeRangeIterable(boolean, long, long) - Method in interface org.apache.druid.segment.incremental.IncrementalIndex.FactsHolder
- 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
forTimeseriesQuery
. - 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.TimestampExtractDynamicExpr - Class in org.apache.druid.query.expression
- TimestampExtractExprMacro.TimestampExtractExpr - Class in org.apache.druid.query.expression
- 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
- TimestampFromEpochFunc() - Constructor for class org.apache.druid.math.expr.Function.TimestampFromEpochFunc
- timestampFunction() - Method in class org.apache.druid.data.input.ListBasedInputRowAdapter
- 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
- TimestampParser - Class in org.apache.druid.java.util.common.parsers
- TimestampParser() - Constructor for class org.apache.druid.java.util.common.parsers.TimestampParser
- TimestampShiftExprMacro - Class in org.apache.druid.query.expression
- TimestampShiftExprMacro() - Constructor for class org.apache.druid.query.expression.TimestampShiftExprMacro
- TimestampSpec - Class in org.apache.druid.data.input.impl
- TimestampSpec(String, String, DateTime) - Constructor for class org.apache.druid.data.input.impl.TimestampSpec
- TIMESTAMPSPEC - org.apache.druid.query.metadata.metadata.SegmentMetadataQuery.AnalysisType
- timeSum(long) - Static method in class org.apache.druid.java.util.emitter.core.ConcurrentTimeCounter
- 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
- to(String, Map<String, Long>) - Method in class org.apache.druid.java.util.metrics.KeyedDiff
- toAccessor() - Method in interface org.apache.druid.query.rowsandcols.column.Column
-
Returns the column as a
ColumnAccessor
. - toAccessor() - Method in class org.apache.druid.query.rowsandcols.column.ColumnAccessorBasedColumn
- toAccessor() - Method in class org.apache.druid.query.rowsandcols.column.ConstantObjectColumn
- toAccessor() - Method in class org.apache.druid.query.rowsandcols.column.DoubleArrayColumn
- toAccessor() - Method in class org.apache.druid.query.rowsandcols.column.IntArrayColumn
- toAccessor() - Method in class org.apache.druid.query.rowsandcols.column.LimitedColumn
- toAccessor() - Method in class org.apache.druid.query.rowsandcols.column.NullColumn
- toAccessor() - Method in class org.apache.druid.query.rowsandcols.column.ObjectArrayColumn
- toAccessor() - Method in class org.apache.druid.query.rowsandcols.concrete.ColumnHolderRACColumn
- toArray() - Method in class org.apache.druid.collections.IntegerSet
- toArray() - Method in class org.apache.druid.data.input.StringTuple
- toArray() - Method in class org.apache.druid.extendedset.utilities.IntList
- toByteArray() - Method in interface org.apache.druid.frame.write.FrameWriter
-
Returns a frame as a newly-allocated byte array.
- toByteArray() - Method in class org.apache.druid.hll.HyperLogLogCollector
- toByteBuffer() - Method in class org.apache.druid.hll.HyperLogLogCollector
- 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.extendedset.intset.ImmutableConciseSet
- toBytes() - Method in class org.apache.druid.query.aggregation.Histogram
- toBytes() - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
- toBytes(ObjectMapper, Object) - Static method in class org.apache.druid.java.util.common.jackson.JacksonUtils
-
Convert the given object to an array of bytes.
- toBytes(Object) - Method in class org.apache.druid.segment.serde.ComplexMetricSerde
-
Converts intermediate representation of aggregate to byte[].
- 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
- toClusteredGroupPartitioner() - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- toCnf(Filter) - Static method in class org.apache.druid.segment.filter.Filters
- toColumnCapabilities() - Method in class org.apache.druid.segment.column.CapabilitiesBasedFormat
- toColumnCapabilities() - Method in interface org.apache.druid.segment.column.ColumnFormat
- toColumnCapabilities() - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumn.Format
- toColumnCapabilities() - Method in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde.NestedColumnFormatV4
- toColumnType() - Method in interface org.apache.druid.segment.column.ColumnCapabilities
- toColumnType(ExpressionType) - Static method in class org.apache.druid.math.expr.ExpressionType
-
Convert
ExpressionType
to the correspondingColumnType
- toConstantMatcherTypeIfPossible(DimensionDictionarySelector, boolean, DruidObjectPredicate<String>) - Static method in class org.apache.druid.segment.filter.ValueMatchers
-
If applying
predicate
toselector
would always return a constant, returns that constant. - toDate(String) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- toDate(String, Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- toDate(String, Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- toDate(String, Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- toDate(String, Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- toDate(String, Granularity.Formatter) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- toDateTime(long) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- toDateTime(long) - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- toDegrees(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- ToDegrees() - Constructor for class org.apache.druid.math.expr.Function.ToDegrees
- toDescriptor() - Method in class org.apache.druid.timeline.DataSegment
- toDescriptor() - Method in class org.apache.druid.timeline.SegmentId
- toErrorResponse() - Method in exception org.apache.druid.error.DruidException
-
Returns this DruidException as an ErrorResponse.
- toExpr() - Method in class org.apache.druid.math.expr.ExprEval
- toFilter() - Method in class org.apache.druid.query.filter.AndDimFilter
- toFilter() - Method in class org.apache.druid.query.filter.ArrayContainsElementFilter
- 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.EqualityFilter
- 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.IsBooleanDimFilter
- 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.NullFilter
- toFilter() - Method in class org.apache.druid.query.filter.OrDimFilter
- toFilter() - Method in class org.apache.druid.query.filter.RangeFilter
- 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() - Method in class org.apache.druid.query.filter.TypedInFilter
- toFilter(DimFilter) - Static method in class org.apache.druid.segment.filter.Filters
- toGroupKey(long, InputRow) - Static method in class org.apache.druid.data.input.Rows
- toHexString(String, long, int) - Method in class org.apache.druid.segment.data.SafeWritableBase
-
Adapted from
BaseStateImpl.toHexString(String, long, int)
- toImmutableBitmap() - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
- toImmutableBitmap(ImmutableBitmap) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
- toImmutableBitmap(T) - Method in interface org.apache.druid.query.BitmapResultFactory
-
Unwraps bitmapResult back to ImmutableBitmap.
- 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.DictionaryEncodedColumnMerger
- toIterable(Object) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- toJson() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- toJson(Object) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- ToJsonStringExprMacro(ObjectMapper) - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.ToJsonStringExprMacro
- tokenNames - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
-
Deprecated.Use
ExprLexer.VOCABULARY
instead. - tokenNames - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
-
Deprecated.Use
ExprParser.VOCABULARY
instead. - toLevel(String) - Static method in enum org.apache.druid.java.util.emitter.core.LoggingEmitter.Level
- toList() - Method in interface org.apache.druid.java.util.common.guava.Sequence
-
This will materialize the entire sequence.
- toList(int) - Method in class org.apache.druid.segment.generator.DataGenerator
-
Put rows from this generator to a list.
- toLong(IPv4Address) - Static method in class org.apache.druid.query.expression.IPv4AddressExprUtils
- toLowerCase(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- toMap() - Method in interface org.apache.druid.java.util.emitter.core.Event
- toMap() - Method in class org.apache.druid.java.util.emitter.service.AlertEvent
- toMap() - Method in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- toMap() - Method in class org.apache.druid.java.util.emitter.service.ServiceMetricEvent
- toMap() - Method in class org.apache.druid.query.context.ResponseContext
- toMap(byte[]) - Method in class org.apache.druid.data.input.impl.DelimitedValueReader
- toMap(byte[]) - Method in class org.apache.druid.data.input.impl.JsonLineReader
- toMap(JsonNode) - Method in class org.apache.druid.data.input.impl.JsonNodeReader
- toMap(String) - Method in class org.apache.druid.data.input.impl.RegexReader
- toMap(InputEntity) - Method in class org.apache.druid.data.input.impl.JsonReader
- toMap(GroupByQuery) - Method in class org.apache.druid.query.groupby.ResultRow
-
Returns a Map representation of the data in this row.
- toMap(T) - Method in class org.apache.druid.data.input.IntermediateRowParsingReader
-
Converts the given intermediate row into a
Map
. - toMap(T) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlattener
- toMap(T) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
-
Convert object to Java
Map
usingObjectFlatteners.FlattenerMaker.getJsonProvider()
andObjectFlatteners.FlattenerMaker.finalizeConversionForMap(java.lang.Object)
to extract and convert data - toMapBasedRow(GroupByQuery) - Method in class org.apache.druid.query.groupby.ResultRow
-
Returns a
Row
representation of the data in this row. - TOMBSTONE - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- TOMBSTONE_LOADSPEC_TYPE - Static variable in class org.apache.druid.timeline.DataSegment
- TombstoneDataStorageModule - Class in org.apache.druid.initialization
- TombstoneDataStorageModule() - Constructor for class org.apache.druid.initialization.TombstoneDataStorageModule
- TombstoneLoadSpec - Class in org.apache.druid.segment.loading
- TombstoneLoadSpec() - Constructor for class org.apache.druid.segment.loading.TombstoneLoadSpec
- TombstonePartitionedChunk<T> - Class in org.apache.druid.timeline.partition
- TombstonePartitionedChunk(T) - Constructor for class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- TombstoneSegmentizerFactory - Class in org.apache.druid.segment.loading
- TombstoneSegmentizerFactory() - Constructor for class org.apache.druid.segment.loading.TombstoneSegmentizerFactory
- TombstoneShardSpec - Class in org.apache.druid.timeline.partition
-
A shard spec to represent tombstones.
- TombstoneShardSpec() - Constructor for class org.apache.druid.timeline.partition.TombstoneShardSpec
- 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. - toNaiveSortMaker() - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- toNormalizedJqPath(List<NestedPathPart>) - Static method in class org.apache.druid.segment.nested.NestedPathFinder
-
Given a list of part finders, convert it to a "normalized" 'jq' path format that is consistent with how
StructuredDataProcessor
constructs field path names - toNormalizedJsonPath(List<NestedPathPart>) - Static method in class org.apache.druid.segment.nested.NestedPathFinder
- toNormalizedOrClauses(Filter) - Static method in class org.apache.druid.segment.filter.Filters
- TOOLCHEST - Static variable in class org.apache.druid.query.operator.WindowOperatorQueryQueryRunnerFactory
- toOptimizedFilter(boolean) - Method in class org.apache.druid.query.filter.AbstractOptimizableDimFilter
- toOptimizedFilter(boolean) - Method in interface org.apache.druid.query.filter.DimFilter
- toPath(DateTime) - Method in class org.apache.druid.java.util.common.granularity.Granularity
- toPlainJavaType(Object) - Method in interface org.apache.druid.java.util.common.parsers.ObjectFlatteners.FlattenerMaker
-
Recursively traverse "json" object using a
JsonProvider
, converting to JavaMap
andList
, potentially transforming viaObjectFlatteners.FlattenerMaker.finalizeConversionForMap(java.lang.Object)
as we go - 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 allTopNAlgorithm
to provide selector value cardinality toTopNParams
(perhaps unecessarily, but that is another matter), but is primarily used byHeapBasedTopNAlgorithm
to serve as its value aggregates store. - TopNColumnAggregatesProcessorFactory - Class in org.apache.druid.query.topn.types
- TopNColumnAggregatesProcessorFactory(ColumnType) - 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
forTopNQuery
. - 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<DimensionAndMetricValueExtractor>) - Constructor for class org.apache.druid.query.topn.TopNResultValue
- TopNSequence<T> - Class in org.apache.druid.java.util.common.guava
-
Simultaneously sorts and limits its input.
- TopNSequence(Sequence<T>, Comparator<T>, int) - Constructor for class org.apache.druid.java.util.common.guava.TopNSequence
- toQueryableIndex() - Method in class org.apache.druid.query.rowsandcols.concrete.QueryableIndexRowsAndColumns
- toRadians(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- ToRadians() - Constructor for class org.apache.druid.math.expr.Function.ToRadians
- toRowsAndColumns() - Method in class org.apache.druid.query.rowsandcols.semantic.DefaultRowsAndColumnsDecorator
- toRowsAndColumns() - Method in interface org.apache.druid.query.rowsandcols.semantic.RowsAndColumnsDecorator
- toRowsAndColumnsDecorator() - Method in class org.apache.druid.query.rowsandcols.LazilyDecoratedRowsAndColumns
- toSingleEventScanResultValues() - Method in class org.apache.druid.query.scan.ScanResultValue
- toStorageAdapter() - Method in class org.apache.druid.query.rowsandcols.ArrayListRowsAndColumns
- toStorageAdapter() - Method in class org.apache.druid.query.rowsandcols.concrete.QueryableIndexRowsAndColumns
- toString() - Method in class org.apache.druid.audit.AuditEntry.Payload
- toString() - Method in class org.apache.druid.audit.AuditInfo
- toString() - Method in class org.apache.druid.audit.RequestInfo
- 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.collections.StupidPool
- toString() - Method in class org.apache.druid.data.input.ColumnsFilter.ExclusionBased
- toString() - Method in class org.apache.druid.data.input.ColumnsFilter.InclusionBased
- toString() - Method in class org.apache.druid.data.input.impl.CloudObjectLocation
- toString() - Method in class org.apache.druid.data.input.impl.CsvInputFormat
- toString() - Method in class org.apache.druid.data.input.impl.DelimitedInputFormat
- toString() - Method in enum org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
- toString() - Method in class org.apache.druid.data.input.impl.DimensionSchema
- toString() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- toString() - Method in class org.apache.druid.data.input.impl.HttpInputSource
- toString() - Method in class org.apache.druid.data.input.impl.HttpInputSourceConfig
- toString() - Method in class org.apache.druid.data.input.impl.InlineInputSource
- toString() - Method in class org.apache.druid.data.input.impl.JsonInputFormat
- toString() - Method in class org.apache.druid.data.input.impl.JSONParseSpec
- toString() - Method in class org.apache.druid.data.input.impl.LocalInputSource
- toString() - Method in enum org.apache.druid.data.input.impl.systemfield.SystemField
- toString() - Method in class org.apache.druid.data.input.impl.systemfield.SystemFields
- toString() - Method in class org.apache.druid.data.input.impl.TimestampSpec
- toString() - Method in class org.apache.druid.data.input.InputSplit
- toString() - Method in class org.apache.druid.data.input.ListBasedInputRow
- toString() - Method in class org.apache.druid.data.input.MapBasedInputRow
- toString() - Method in class org.apache.druid.data.input.MapBasedRow
- toString() - Method in class org.apache.druid.data.input.SegmentsSplitHintSpec
- toString() - Method in class org.apache.druid.data.input.StringTuple
- toString() - Method in class org.apache.druid.extendedset.intset.AbstractIntSet
- toString() - Method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- toString() - Method in class org.apache.druid.frame.key.ByteRowKeyComparator
- toString() - Method in class org.apache.druid.frame.key.ClusterBy
- toString() - Method in class org.apache.druid.frame.key.ClusterByPartition
- toString() - Method in class org.apache.druid.frame.key.ClusterByPartitions
- toString() - Method in class org.apache.druid.frame.key.KeyColumn
- toString() - Method in class org.apache.druid.frame.key.RowKey
- toString() - Method in class org.apache.druid.frame.key.RowKeyComparator
- toString() - Method in class org.apache.druid.frame.key.RowKeyComparisonRunLengths
- toString() - Method in class org.apache.druid.frame.key.RunLengthEntry
- toString() - Method in class org.apache.druid.frame.processor.ReturnOrAwait
- toString() - Method in class org.apache.druid.frame.processor.TournamentTree
- 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.hll.HyperLogLogCollector
- toString() - Method in class org.apache.druid.indexer.partitions.DimensionRangePartitionsSpec
- toString() - Method in class org.apache.druid.indexer.partitions.DynamicPartitionsSpec
- toString() - Method in class org.apache.druid.indexer.partitions.HashedPartitionsSpec
- toString() - Method in class org.apache.druid.indexer.partitions.SingleDimensionPartitionsSpec
- toString() - Method in class org.apache.druid.indexer.Property
- toString() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrors
- toString() - Method in class org.apache.druid.indexer.report.IngestionStatsAndErrorsTaskReport
- toString() - Method in class org.apache.druid.indexer.report.KillTaskReport.Stats
- toString() - Method in class org.apache.druid.indexer.TaskIdentifier
- toString() - Method in class org.apache.druid.indexer.TaskLocation
- toString() - Method in class org.apache.druid.indexer.TaskStatus
- toString() - Method in class org.apache.druid.indexer.TaskStatusPlus
- toString() - Method in class org.apache.druid.java.util.common.Either
- toString() - Method in class org.apache.druid.java.util.common.granularity.AllGranularity
- toString() - Method in class org.apache.druid.java.util.common.granularity.DurationGranularity
- toString() - Method in class org.apache.druid.java.util.common.granularity.NoneGranularity
- toString() - Method in class org.apache.druid.java.util.common.granularity.PeriodGranularity
- toString() - Method in class org.apache.druid.java.util.common.HumanReadableBytes
- toString() - Method in class org.apache.druid.java.util.common.logger.Logger
- toString() - Method in class org.apache.druid.java.util.common.NonnullPair
- toString() - Method in class org.apache.druid.java.util.common.Pair
- toString() - Method in class org.apache.druid.java.util.common.parsers.JSONPathFieldSpec
- toString() - Method in enum org.apache.druid.java.util.common.parsers.JSONPathFieldType
- toString() - Method in class org.apache.druid.java.util.common.parsers.JSONPathSpec
- toString() - Method in enum org.apache.druid.java.util.common.StringEncoding
- toString() - Method in class org.apache.druid.java.util.common.Triple
- toString() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- toString() - Method in class org.apache.druid.java.util.emitter.core.ComposingEmitter
- toString() - Method in class org.apache.druid.java.util.emitter.core.FeedUriExtractor
- toString() - Method in class org.apache.druid.java.util.emitter.core.HttpEmitterConfig
- toString() - Method in class org.apache.druid.java.util.emitter.core.HttpPostEmitter
- toString() - Method in class org.apache.druid.java.util.emitter.core.LoggingEmitter
- toString() - Method in class org.apache.druid.java.util.emitter.core.LoggingEmitterConfig
- toString() - Method in class org.apache.druid.java.util.emitter.core.NoopEmitter
- toString() - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitter
- toString() - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriEmitterConfig
- toString() - Method in class org.apache.druid.java.util.emitter.core.ParametrizedUriExtractor
- toString() - Method in class org.apache.druid.java.util.emitter.service.ServiceEmitter
- toString() - Method in class org.apache.druid.java.util.http.client.HttpClientProxyConfig
- toString() - Method in class org.apache.druid.js.JavaScriptConfig
- toString() - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- toString() - Method in class org.apache.druid.metadata.DefaultPasswordProvider
- toString() - Method in class org.apache.druid.metadata.EnvironmentVariableDynamicConfigProvider
- toString() - Method in class org.apache.druid.metadata.EnvironmentVariablePasswordProvider
- toString() - Method in class org.apache.druid.metadata.MetadataStorageConnectorConfig
- toString() - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnHeader
- 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.ExpressionLambdaAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- toString() - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- 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.GroupingAggregatorFactory
- 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.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.SingleValueAggregator
- toString() - Method in class org.apache.druid.query.aggregation.SingleValueAggregatorFactory
- 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.context.ResponseContext.AbstractKey
- 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.ArrayContainsElementFilter
- 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.EqualityFilter
- 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.FilterBundle.BundleInfo
- toString() - Method in class org.apache.druid.query.filter.FilterBundle.IndexBundleInfo
- toString() - Method in class org.apache.druid.query.filter.FilterBundle.MatcherBundleInfo
- 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.IsBooleanDimFilter
- toString() - Method in class org.apache.druid.query.filter.JavaScriptDimFilter
- toString() - Method in class org.apache.druid.query.filter.LikeDimFilter.LikeMatcher
- 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.NullFilter.NullPredicateFactory
- toString() - Method in class org.apache.druid.query.filter.NullFilter
- toString() - Method in class org.apache.druid.query.filter.OrDimFilter
- toString() - Method in class org.apache.druid.query.filter.RangeFilter
- 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.TypedInFilter
- toString() - Method in class org.apache.druid.query.filter.vector.VectorMatch
- toString() - Method in class org.apache.druid.query.FilteredDataSource
- 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.IntKey
- toString() - Method in class org.apache.druid.query.groupby.epinephelinae.ReusableEntry
- 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 enum org.apache.druid.query.metadata.metadata.AggregatorMergeStrategy
- 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.operator.ColumnWithDirection
- toString() - Method in class org.apache.druid.query.operator.NaivePartitioningOperatorFactory
- toString() - Method in class org.apache.druid.query.operator.NaiveSortOperatorFactory
- toString() - Method in class org.apache.druid.query.operator.OffsetLimit
- toString() - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- toString() - Method in class org.apache.druid.query.operator.window.ComposingProcessor
- toString() - Method in class org.apache.druid.query.operator.window.ranking.WindowPercentileProcessor
- toString() - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- toString() - Method in class org.apache.druid.query.operator.window.ranking.WindowRankProcessor
- toString() - Method in class org.apache.druid.query.operator.window.ranking.WindowRowNumberProcessor
- toString() - Method in class org.apache.druid.query.operator.window.value.WindowOffsetProcessor
- toString() - Method in class org.apache.druid.query.operator.window.value.WindowValueProcessorBase
- toString() - Method in class org.apache.druid.query.operator.window.WindowFrame
- toString() - Method in class org.apache.druid.query.operator.window.WindowFramedAggregateProcessor
- toString() - Method in class org.apache.druid.query.operator.window.WindowOperatorFactory
- toString() - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- 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.NaturalComparator
- 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 class org.apache.druid.query.QueryContext
- 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.QueryException
- toString() - Method in class org.apache.druid.query.QueryResourceId
- toString() - Method in class org.apache.druid.query.Result
- toString() - Method in enum org.apache.druid.query.scan.ScanQuery.Order
- toString() - Method in class org.apache.druid.query.scan.ScanQuery.OrderBy
- 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.SegmentDescriptor
- 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.query.UnnestDataSource
- toString() - Method in class org.apache.druid.segment.AutoTypeColumnSchema
- toString() - Method in class org.apache.druid.segment.column.BaseTypeSignature
- toString() - Method in enum org.apache.druid.segment.column.ColumnCapabilities.Capable
- toString() - Method in class org.apache.druid.segment.column.RowSignature
- toString() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.FrontCoded
- toString() - Method in class org.apache.druid.segment.column.StringEncodingStrategy.Utf8
- 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.RoaringBitmapSerdeFactory
- toString() - Method in class org.apache.druid.segment.DefaultColumnFormatConfig
- toString() - Method in class org.apache.druid.segment.filter.AndFilter
- toString() - Method in class org.apache.druid.segment.filter.BoundFilter
- 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.IsBooleanFilter
- toString() - Method in class org.apache.druid.segment.filter.LikeFilter
- 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.incremental.ParseExceptionReport
- toString() - Method in class org.apache.druid.segment.incremental.RowIngestionMetersTotals
- 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.filter.rewrite.JoinFilterRewriteConfig
- 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.nested.FieldTypeInfo.MutableTypeSet
- toString() - Method in class org.apache.druid.segment.nested.FieldTypeInfo.TypeSet
- toString() - Method in class org.apache.druid.segment.nested.NestedPathArrayElement
- toString() - Method in class org.apache.druid.segment.nested.NestedPathField
- toString() - Method in class org.apache.druid.segment.nested.StructuredData
- toString() - Method in class org.apache.druid.segment.NestedDataColumnSchema
- 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.SchemaPayload
- toString() - Method in class org.apache.druid.segment.SchemaPayloadPlus
- toString() - Method in class org.apache.druid.segment.SegmentMetadata
- toString() - Method in class org.apache.druid.segment.SegmentSchemaMapping
- 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.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.virtual.ListFilteredVirtualColumn
- toString() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- toString() - Method in class org.apache.druid.segment.VirtualColumns
- toString() - Method in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- toString() - Method in class org.apache.druid.timeline.CompactionState
- toString() - Method in class org.apache.druid.timeline.DataSegment
- toString() - Method in class org.apache.druid.timeline.partition.BuildingDimensionRangeShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.BuildingHashBasedNumberedShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.BuildingNumberedShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.BuildingSingleDimensionShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.DimensionRangeBucketShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.HashBasedNumberedShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.HashBucketShardSpec
- toString() - Method in enum org.apache.druid.timeline.partition.HashPartitionFunction
- toString() - Method in class org.apache.druid.timeline.partition.IntegerPartitionChunk
- toString() - Method in class org.apache.druid.timeline.partition.LinearShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.NoneShardSpec
-
Deprecated.
- toString() - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.NumberedOverwritingPartitionChunk
- toString() - Method in class org.apache.druid.timeline.partition.NumberedPartitionChunk
- toString() - Method in class org.apache.druid.timeline.partition.NumberedShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.PartitionHolder
- toString() - Method in class org.apache.druid.timeline.partition.SingleDimensionRangeBucketShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- toString() - Method in class org.apache.druid.timeline.partition.SingleElementPartitionChunk
-
Deprecated.
- toString() - Method in class org.apache.druid.timeline.partition.StringPartitionChunk
- toString() - Method in class org.apache.druid.timeline.partition.TombstonePartitionedChunk
- toString() - Method in class org.apache.druid.timeline.partition.TombstoneShardSpec
- toString() - Method in class org.apache.druid.timeline.SegmentId
- toString() - Method in class org.apache.druid.timeline.SegmentStatusInCluster
- toString() - Method in class org.apache.druid.timeline.TimelineObjectHolder
- toString(IPv4Address) - Static method in class org.apache.druid.query.expression.IPv4AddressExprUtils
- toStringBase() - Method in class org.apache.druid.java.util.emitter.core.BaseHttpEmittingConfig
- 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. - toUpperCase(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- toUri(String) - Method in class org.apache.druid.data.input.impl.CloudObjectLocation
- TournamentTree - Class in org.apache.druid.frame.processor
-
Tree-of-losers tournament tree used for K-way merging.
- TournamentTree(int, IntComparator) - Constructor for class org.apache.druid.frame.processor.TournamentTree
-
Creates a tree with a certain number of elements.
- toUtf8() - Method in class org.apache.druid.query.filter.InDimFilter.ValuesSet
- toUtf8(String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Converts a string to a UTF-8 byte array.
- toUtf8ByteBuffer(String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Converts a string to UTF-8 bytes, returning them as a newly-allocated on-heap
ByteBuffer
. - toUtf8Nullable(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- toUtf8WithLimit(String, ByteBuffer) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Encodes "string" into the buffer "byteBuffer", using no more than the number of bytes remaining in the buffer.
- toUtf8WithNullToEmpty(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- toValue() - Method in enum org.apache.druid.query.extraction.StringFormatExtractionFn.NullHandling
- toValue(DateTime) - Method in class org.apache.druid.math.expr.Function.TimestampFromEpochFunc
- toValue(DateTime) - Method in class org.apache.druid.math.expr.Function.UnixTimestampFunc
- toWireTransferable() - Method in class org.apache.druid.query.rowsandcols.LazilyDecoratedRowsAndColumns
- toYielder(OutType, YieldingAccumulator<OutType, RowsAndColumns>) - Method in class org.apache.druid.query.operator.OperatorSequence
- toYielder(OutType, YieldingAccumulator<OutType, ScanResultValue>) - Method in class org.apache.druid.query.scan.ScanQueryOffsetSequence
- toYielder(OutType, YieldingAccumulator<OutType, Out>) - Method in class org.apache.druid.java.util.common.guava.MappedSequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.common.guava.CombiningSequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.BaseSequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.ConcatSequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.ExplodingSequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.FilteredSequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.LazySequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.MergeSequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.ParallelMergeCombiningSequence
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in interface org.apache.druid.java.util.common.guava.Sequence
-
Return a Yielder for accumulated sequence.
- toYielder(OutType, YieldingAccumulator<OutType, T>) - Method in class org.apache.druid.java.util.common.guava.SkippingSequence
- trace(String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- trace(Marker, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- TRACE - org.apache.druid.java.util.emitter.core.LoggingEmitter.Level
- TRAILER_LENGTH - Static variable in class org.apache.druid.frame.file.FrameFileWriter
- TransferredBuffer(CellWriter, AbstractSerializablePairLongObjectColumnHeader<?>) - Constructor for class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectBufferStore.TransferredBuffer
- transferTo(WritableByteChannel) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnHeader
- transferTo(WritableByteChannel) - Method in class org.apache.druid.segment.serde.cell.IndexWriter
- transferToRowWriter(ByteBufferProvider, SegmentWriteOutMedium) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectBufferStore
-
each call transfers the temporary buffer into an encoded, block-compessed buffer of the segment.
- transform(Function<T, RetType>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- transform(Function<T, RetType>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- transform(ListenableFuture<T>, Function<T, R>) - Static method in class org.apache.druid.common.guava.FutureUtils
-
Like
Futures.transform(com.google.common.util.concurrent.ListenableFuture<I>, com.google.common.base.Function<? super I, ? extends O>, java.util.concurrent.Executor)
, but works better with lambdas due to not having overloads. - 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
- Transform - Interface in org.apache.druid.segment.transform
-
A row transform that is part of a
TransformSpec
. - 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. - transformAsync(ListenableFuture<T>, AsyncFunction<T, R>) - Static method in class org.apache.druid.common.guava.FutureUtils
-
Like
Futures.transformAsync(ListenableFuture, AsyncFunction, java.util.concurrent.Executor)
, but works better with lambdas due to not having overloads. - transformCat(Function<T, Iterable<RetType>>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- transformCat(Function<T, Iterator<RetType>>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterator
- TransformedInputRow - Class in org.apache.druid.segment.transform
- TransformedInputRow(InputRow, Map<String, RowFunction>) - Constructor for class org.apache.druid.segment.transform.TransformedInputRow
- Transformer - Class in org.apache.druid.segment.transform
- transformFromDouble(double) - Static method in class org.apache.druid.frame.field.TransformUtils
-
Transforms a double into a form where it can be compared as unsigned bytes without decoding.
- transformFromFloat(float) - Static method in class org.apache.druid.frame.field.TransformUtils
-
Transforms a float into a form where it can be compared as unsigned bytes without decoding.
- transformFromLong(long) - Static method in class org.apache.druid.frame.field.TransformUtils
-
Transforms a long into a form where it can be compared as unsigned bytes without decoding.
- transformIfNeeded(SanitizableException) - Method in interface org.apache.druid.common.exception.ErrorResponseTransformStrategy
-
For a given
SanitizableException
apply the transformation strategy and return the sanitized Exception if the transformation stategy was applied. - transformIfNeeded(SanitizableException) - Method in class org.apache.druid.common.exception.NoErrorResponseTransformStrategy
- transformIndexedIterator(Indexed<T>) - Method in class org.apache.druid.segment.DictionaryMergingIterator
- 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
- TransformUtils - Class in org.apache.druid.frame.field
-
Utility methods to map the primitive numeric types into an equi-wide byte representation, such that the given byte sequence preserves the ordering of the original type when done byte comparison.
- TransformUtils() - Constructor for class org.apache.druid.frame.field.TransformUtils
- TREE - org.apache.druid.java.util.common.parsers.JSONPathFieldType
- TriConsumer<T,U,V> - Interface in org.apache.druid.java.util.common.function
-
Based on
BiConsumer
- trim(RowKey, int) - Method in class org.apache.druid.frame.key.RowKeyReader
-
Trim a key to a particular fieldCount.
- 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
- trimmedKeyReader(int) - Method in class org.apache.druid.frame.key.RowKeyReader
-
Trims the key reader to a particular fieldCount.
- TrinaryFn<Type1,Type2,Type3,OutType> - Interface in org.apache.druid.java.util.common.guava.nary
- trinaryTransform(Iterable<InType1>, Iterable<InType2>, TrinaryFn<T, InType1, InType2, RetType>) - Method in class org.apache.druid.java.util.common.guava.FunctionalIterable
- TrinaryTransformIterable<Type1,Type2,Type3,RetType> - Class in org.apache.druid.java.util.common.guava.nary
- TrinaryTransformIterable(Iterable<Type1>, Iterable<Type2>, Iterable<Type3>, TrinaryFn<Type1, Type2, Type3, RetType>) - Constructor for class org.apache.druid.java.util.common.guava.nary.TrinaryTransformIterable
- TrinaryTransformIterator<Type1,Type2,Type3,RetType> - Class in org.apache.druid.java.util.common.guava.nary
- TrinaryTransformIterator(Iterator<Type1>, Iterator<Type2>, Iterator<Type3>, TrinaryFn<Type1, Type2, Type3, RetType>) - Constructor for class org.apache.druid.java.util.common.guava.nary.TrinaryTransformIterator
- Triple<T1,T2,T3> - Class in org.apache.druid.java.util.common
- Triple(T1, T2, T3) - Constructor for class org.apache.druid.java.util.common.Triple
- TRUE - org.apache.druid.query.filter.DruidPredicateMatch
-
Value matches
- TRUE - org.apache.druid.query.QueryContexts.Vectorize
- TRUE - org.apache.druid.segment.column.ColumnCapabilities.Capable
- TrueDimFilter - Class in org.apache.druid.query.filter
- TrueFilter - Class in org.apache.druid.segment.filter
- TRUNCATED - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
Indicates if a
ResponseContext
was truncated during serialization. - TRUNCATED_RESPONSE_CONTEXT_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- 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
- tryParse(String, String) - Static method in class org.apache.druid.timeline.SegmentId
-
Tries to parse a segment id from the given String representation, or returns null on failure.
- tryParseDouble(Object, double) - Static method in class org.apache.druid.java.util.common.Numbers
-
Try parsing the given Number or String object val as double.
- tryParseFloat(Object, float) - Static method in class org.apache.druid.java.util.common.Numbers
-
Try parsing the given Number or String object val as float.
- tryParseJdbcUriParameters(String, boolean) - Static method in class org.apache.druid.utils.ConnectionUriUtils
-
This method tries to determine the correct type of database for a given JDBC connection string URI, then load the driver using reflection to parse the uri parameters, returning the set of keys which can be used for JDBC parameter whitelist validation.
- TryParseJsonExprMacro(ObjectMapper) - Constructor for class org.apache.druid.query.expression.NestedDataExpressions.TryParseJsonExprMacro
- tryParseLong(Object, long) - Static method in class org.apache.druid.java.util.common.Numbers
-
Try parsing the given Number or String object val as long.
- tryParseLong(String) - Static method in class org.apache.druid.common.guava.GuavaUtils
-
To fix semantic difference of Longs.tryParse() from Long.parseLong (Longs.tryParse() returns null for '+' started value)
- tryParseMariaDb2xConnectionUri(String) - Static method in class org.apache.druid.utils.ConnectionUriUtils
- tryParseMariaDb3xConnectionUri(String) - Static method in class org.apache.druid.utils.ConnectionUriUtils
- tryParseMySqlConnectionUri(String) - Static method in class org.apache.druid.utils.ConnectionUriUtils
- tryParsePostgresConnectionUri(String) - Static method in class org.apache.druid.utils.ConnectionUriUtils
- trySkipCache(int, long, long) - Static method in class org.apache.druid.java.util.common.io.NativeIO
-
Remove pages from the file system page cache when they wont be accessed again
- type - Variable in class org.apache.druid.segment.column.BaseTypeSignature
- type() - Method in class org.apache.druid.frame.Frame
- type() - Method in class org.apache.druid.math.expr.ExprEval
- type(String) - Method in class org.apache.druid.audit.AuditEntry.Builder
- TYPE - Static variable in class org.apache.druid.data.input.MaxSizeSplitHintSpec
- TYPE - Static variable in class org.apache.druid.data.input.SegmentsSplitHintSpec
- TYPE - Static variable in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
- TYPE - Static variable in class org.apache.druid.query.DruidMetrics
- TYPE - Static variable in class org.apache.druid.query.expression.HyperUniqueExpressions
- TYPE - Static variable in class org.apache.druid.segment.AutoTypeColumnSchema
- TYPE - Static variable in class org.apache.druid.segment.incremental.OnheapIncrementalIndex.Spec
- TYPE - Static variable in class org.apache.druid.timeline.partition.HashBasedNumberedPartialShardSpec
- TYPE_COMPLEX - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_DOUBLE - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_DOUBLE_ARRAY - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_FLOAT - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_FLOAT_ARRAY - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_KEY - Static variable in class org.apache.druid.data.input.impl.CombiningInputSource
- TYPE_KEY - Static variable in class org.apache.druid.data.input.impl.CsvInputFormat
- TYPE_KEY - Static variable in class org.apache.druid.data.input.impl.DelimitedInputFormat
- TYPE_KEY - Static variable in class org.apache.druid.data.input.impl.HttpInputSource
- TYPE_KEY - Static variable in class org.apache.druid.data.input.impl.InlineInputSource
- TYPE_KEY - Static variable in class org.apache.druid.data.input.impl.JsonInputFormat
- TYPE_KEY - Static variable in class org.apache.druid.data.input.impl.LocalInputSource
- TYPE_KEY - Static variable in class org.apache.druid.data.input.impl.RegexInputFormat
- TYPE_KEY - Static variable in class org.apache.druid.metadata.DefaultPasswordProvider
- TYPE_KEY - Static variable in class org.apache.druid.metadata.EnvironmentVariablePasswordProvider
- TYPE_LONG - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_LONG_ARRAY - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_NAME - Static variable in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesSerde
- TYPE_NAME - Static variable in class org.apache.druid.query.aggregation.hyperloglog.PreComputedHyperUniquesSerde
- TYPE_NAME - Static variable in class org.apache.druid.query.aggregation.SerializablePairLongDoubleComplexMetricSerde
- TYPE_NAME - Static variable in class org.apache.druid.query.aggregation.SerializablePairLongFloatComplexMetricSerde
- TYPE_NAME - Static variable in class org.apache.druid.query.aggregation.SerializablePairLongLongComplexMetricSerde
- TYPE_NAME - Static variable in class org.apache.druid.query.aggregation.SerializablePairLongStringComplexMetricSerde
- TYPE_NAME - Static variable in class org.apache.druid.segment.nested.NestedDataComplexTypeSerde
- TYPE_NAME - Static variable in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- TYPE_NAME - Static variable in class org.apache.druid.storage.local.LocalFileStorageConnectorProvider
- TYPE_NAME_LENGTH_POSITION - Static variable in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- TYPE_NAME_POSITION - Static variable in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- TYPE_PROPERTY - Static variable in interface org.apache.druid.data.input.InputFormat
- TYPE_PROPERTY - Static variable in interface org.apache.druid.data.input.InputSource
- TYPE_REFERENCE_MAP_STRING_BOOLEAN - Static variable in class org.apache.druid.java.util.common.jackson.JacksonUtils
- TYPE_REFERENCE_MAP_STRING_OBJECT - Static variable in class org.apache.druid.java.util.common.jackson.JacksonUtils
- TYPE_REFERENCE_MAP_STRING_STRING - Static variable in class org.apache.druid.java.util.common.jackson.JacksonUtils
- TYPE_STRING - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_STRING_ARRAY - Static variable in class org.apache.druid.frame.write.columnar.FrameColumnWriters
- TYPE_VISUAL - Static variable in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
- TypedConstantValueMatcherFactory(ExprEval<?>, DruidPredicateFactory) - Constructor for class org.apache.druid.query.filter.EqualityFilter.TypedConstantValueMatcherFactory
- TypeDescriptor - Interface in org.apache.druid.segment.column
- TypedInFilter - Class in org.apache.druid.query.filter
-
Approximately like the SQL 'IN' filter, with the main difference being that this will match NULL values if contained in the values list instead of ignoring them.
- TypedInFilter(String, ColumnType, List<?>, List<?>, FilterTuning) - Constructor for class org.apache.druid.query.filter.TypedInFilter
-
Creates a new filter.
- TypedInFilter.PredicateFactory - Class in org.apache.druid.query.filter
- TypeFactory<Type extends TypeSignature<? extends TypeDescriptor>> - Interface in org.apache.druid.segment.column
-
Create
TypeSignature
of aTypeDescriptor
. - Types - Class in org.apache.druid.segment.column
- Types() - Constructor for class org.apache.druid.segment.column.Types
- Types.IncompatibleTypeException - Exception in org.apache.druid.segment.column
- Types.InvalidCastBooleanException - Exception in org.apache.druid.segment.column
- Types.InvalidCastException - Exception in org.apache.druid.segment.column
- TypeSet(byte) - Constructor for class org.apache.druid.segment.nested.FieldTypeInfo.TypeSet
- TypeSignature<Type extends TypeDescriptor> - Interface in org.apache.druid.segment.column
-
This interface serves as a common foundation for Druids native type system, and provides common methods for reasoning about and handling type matters.
- TypeStrategies - Class in org.apache.druid.segment.column
- TypeStrategies() - Constructor for class org.apache.druid.segment.column.TypeStrategies
- TypeStrategies.ArrayTypeStrategy - Class in org.apache.druid.segment.column
-
Read and write a non-null ARRAY which is permitted to have null elements (all elements are always read and written with a
NullableTypeStrategy
wrapper on theTypeStrategy
of theTypeSignature.getElementType()
. - TypeStrategies.DoubleTypeStrategy - Class in org.apache.druid.segment.column
-
Read and write non-null DOUBLE values.
- TypeStrategies.FloatTypeStrategy - Class in org.apache.druid.segment.column
-
Read and write non-null FLOAT values.
- TypeStrategies.LongTypeStrategy - Class in org.apache.druid.segment.column
-
Read and write non-null LONG values.
- TypeStrategies.StringTypeStrategy - Class in org.apache.druid.segment.column
-
Read and write non-null UTF8 encoded String values.
- TypeStrategy<T> - Interface in org.apache.druid.segment.column
-
TypeStrategy provides value comparison and binary serialization for Druid types.
U
- ulp(Expr.VectorInputBindingInspector, Expr) - Static method in class org.apache.druid.math.expr.vector.VectorMathProcessors
- Ulp() - Constructor for class org.apache.druid.math.expr.Function.Ulp
- umbrellaInterval(Iterable<Interval>) - Static method in class org.apache.druid.java.util.common.JodaUtils
- unapply(String) - Method in class org.apache.druid.query.extraction.MapLookupExtractor
- unapply(String) - Method in class org.apache.druid.query.lookup.ImmutableLookupMap.ImmutableLookupExtractor
- unapply(String) - Method in class org.apache.druid.query.lookup.LookupExtractor
-
Reverse lookup from a given value.
- unapplyAll(Set<String>) - Method in class org.apache.druid.query.extraction.MapLookupExtractor
- unapplyAll(Set<String>) - Method in class org.apache.druid.query.lookup.LookupExtractor
-
Reverse lookup from a given set of values.
- UnaryOpExprContext(ExprParser.ExprContext) - Constructor for class org.apache.druid.math.expr.antlr.ExprParser.UnaryOpExprContext
- UNAUTHORIZED - org.apache.druid.error.DruidException.Category
-
Means that the error is a problem with authorization.
- UNAUTHORIZED - org.apache.druid.query.QueryException.FailType
- UNAUTHORIZED_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- unbounded() - Static method in class org.apache.druid.query.operator.window.WindowFrame
- UNBOUNDED - org.apache.druid.query.filter.RangeFilter.RangeType
-
-∞...∞
- unboundedTracker() - Static method in class org.apache.druid.frame.channel.ByteTracker
- UNCATEGORIZED - org.apache.druid.error.DruidException.Category
-
A catch-all for any time when we cannot come up with a meaningful categorization.
- UNCOMPRESSED - org.apache.druid.segment.data.CompressionStrategy
- UNCOMPRESSED_MULTI_VALUE - org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.VERSION
- UNCOMPRESSED_SINGLE_VALUE - org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.VERSION
- UNCOMPRESSED_WITH_FLAGS - org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.VERSION
- UncompressedCompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.UncompressedCompressor
- UncompressedDecompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.UncompressedDecompressor
- UNCOVERED_INTERVALS - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
Lists intervals for which NO segment is present.
- UNCOVERED_INTERVALS_LIMIT_KEY - Static variable in class org.apache.druid.query.QueryContexts
- UNCOVERED_INTERVALS_OVERFLOWED - Static variable in class org.apache.druid.query.context.ResponseContext.Keys
-
Indicates if the number of uncovered intervals exceeded the limit (true/false).
- undo() - Method in class org.apache.druid.frame.write.columnar.ComplexFrameColumnWriter
- undo() - Method in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- undo() - Method in class org.apache.druid.frame.write.columnar.DoubleFrameColumnWriter
- undo() - Method in class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- undo() - Method in class org.apache.druid.frame.write.columnar.FloatFrameColumnWriter
- undo() - Method in class org.apache.druid.frame.write.columnar.FloatFrameMaker
- undo() - Method in interface org.apache.druid.frame.write.columnar.FrameColumnWriter
-
Reverts the last added value.
- undo() - Method in class org.apache.druid.frame.write.columnar.LongFrameColumnWriter
- undo() - Method in class org.apache.druid.frame.write.columnar.LongFrameMaker
- undo() - Method in class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
- undo() - Method in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
- UnexpectedMultiValueDimensionException - Exception in org.apache.druid.query.groupby.epinephelinae
- UnexpectedMultiValueDimensionException(String) - Constructor for exception org.apache.druid.query.groupby.epinephelinae.UnexpectedMultiValueDimensionException
- unfinished(T) - Static method in class org.apache.druid.java.util.http.client.response.ClientResponse
- unfinished(T, boolean) - Static method in class org.apache.druid.java.util.http.client.response.ClientResponse
- UNIFORM - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- 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(Iterable<ImmutableBitmap>) - Method in class org.apache.druid.query.DefaultBitmapResultFactory
- union(Iterable<ImmutableConciseSet>) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- 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(Iterator<ImmutableConciseSet>) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- union(Set<T>, Set<T>) - Static method in class org.apache.druid.utils.CollectionUtils
-
Intersection of two sets:
C = A ∪ B
. - union(ImmutableBitmap) - Method in interface org.apache.druid.collections.bitmap.ImmutableBitmap
-
Compute the bitwise-or of this bitmap with another bitmap.
- union(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedConciseBitmap
- union(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
- union(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableConciseBitmap
- union(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedImmutableRoaringBitmap
- union(ImmutableBitmap) - Method in class org.apache.druid.collections.bitmap.WrappedRoaringBitmap
- union(ImmutableConciseSet...) - Static method in class org.apache.druid.extendedset.intset.ImmutableConciseSet
- unionBitmaps(BitmapFactory, Indexed<ImmutableBitmap>) - Static method in class org.apache.druid.segment.serde.CombineFirstTwoEntriesIndexed
-
Union the first two bitmaps.
- UnionDataSource - Class in org.apache.druid.query
-
Reperesents a UNION ALL of two or more datasources.
- UnionDataSource(List<DataSource>) - 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
- UniqueLongArrayIndex - Class in org.apache.druid.segment.join.table
-
An
IndexedTable.Index
backed by an int array. - Unit - Class in org.apache.druid.java.util.common
-
A type that has exactly one value.
- UnivariateDoubleFunctionVectorValueProcessor<TInput> - Class in org.apache.druid.math.expr.vector
-
common machinery for processing single input operators and functions, which should always treat null input as null output, and are backed by a primitive value instead of an object value (and need to use the null vector instead of checking the vector itself for nulls) this one is specialized for producing double[], see
UnivariateLongFunctionVectorValueProcessor
for long[] primitives. - UnivariateDoubleFunctionVectorValueProcessor(ExprVectorProcessor<TInput>, int) - Constructor for class org.apache.druid.math.expr.vector.UnivariateDoubleFunctionVectorValueProcessor
- UnivariateFunction() - Constructor for class org.apache.druid.math.expr.Function.UnivariateFunction
- UnivariateFunctionVectorObjectProcessor<TInput,TOutput> - Class in org.apache.druid.math.expr.vector
-
common machinery for processing single input operators and functions, which are backed by an object value instead of a primitive value (so do not need to use the null vector, and instead can check the value vector itself for nulls)
- UnivariateFunctionVectorObjectProcessor(ExprVectorProcessor<TInput>, int, TOutput) - Constructor for class org.apache.druid.math.expr.vector.UnivariateFunctionVectorObjectProcessor
- UnivariateLongFunctionVectorValueProcessor<TInput> - Class in org.apache.druid.math.expr.vector
-
common machinery for processing single input operators and functions, which should always treat null input as null output, and are backed by a primitive value instead of an object value (and need to use the null vector instead of checking the vector itself for nulls) this one is specialized for producing long[], see
UnivariateDoubleFunctionVectorValueProcessor
for double[] primitives. - UnivariateLongFunctionVectorValueProcessor(ExprVectorProcessor<TInput>, int) - Constructor for class org.apache.druid.math.expr.vector.UnivariateLongFunctionVectorValueProcessor
- UnivariateMathFunction() - Constructor for class org.apache.druid.math.expr.Function.UnivariateMathFunction
- UnixTimestampFunc() - Constructor for class org.apache.druid.math.expr.Function.UnixTimestampFunc
- unknown() - Static method in class org.apache.druid.indexer.TaskLocation
- UNKNOWN - org.apache.druid.query.filter.DruidPredicateMatch
-
Value is unknown to match, for example from a null input to a predicate which does not match null as true or false
- UNKNOWN - org.apache.druid.query.QueryException.FailType
- UNKNOWN - org.apache.druid.segment.column.ColumnCapabilities.Capable
- UNKNOWN - org.apache.druid.segment.column.RowSignature.Finalization
-
Aggregation results may or may not be finalized.
- UNKNOWN - Static variable in interface org.apache.druid.timeline.partition.ShardSpec.Type
- UNKNOWN_ATOMIC_UPDATE_GROUP_SIZE - Static variable in class org.apache.druid.timeline.partition.PartitionIds
- UNKNOWN_COMPLEX - Static variable in class org.apache.druid.math.expr.ExpressionType
- UNKNOWN_COMPLEX - Static variable in class org.apache.druid.segment.column.ColumnType
-
Placeholder type for an "unknown" complex, which is used when the complex type name was "lost" or unavailable for whatever reason, to indicate an opaque type that cannot be generically handled with normal complex type handling mechanisms.
- UNKNOWN_EXCEPTION_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- UNKNOWN_FIELD_COUNT - Static variable in class org.apache.druid.data.input.impl.DelimitedBytes
-
Parameter for
DelimitedBytes.split(byte[], byte, int)
signifying that we do not know the expected number of fields. - UNKNOWN_INPUTS - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression has inputs whose type was unresolveable
- UNKNOWN_LEVEL - Static variable in class org.apache.druid.frame.processor.SuperSorter
- UNKNOWN_NUM_CORE_PARTITIONS - Static variable in class org.apache.druid.timeline.partition.DimensionRangeShardSpec
- UNKNOWN_NUM_CORE_PARTITIONS - Static variable in class org.apache.druid.timeline.partition.SingleDimensionShardSpec
- UNKNOWN_SIZE - Static variable in interface org.apache.druid.data.input.impl.CloudObjectSplitWidget
- UNKNOWN_TOTAL - Static variable in class org.apache.druid.frame.processor.SuperSorter
- UNKNOWN_VERSION - Static variable in class org.apache.druid.utils.JvmUtils
- UnknownTypeComplexColumn - Class in org.apache.druid.segment.column
- UnknownTypeComplexColumn() - Constructor for class org.apache.druid.segment.column.UnknownTypeComplexColumn
- unlimited() - Static method in class org.apache.druid.frame.allocation.HeapMemoryAllocator
-
Create an allocator that is "unlimited", which, of course, means it is limited only by available JVM heap.
- unlimited() - Static method in class org.apache.druid.frame.processor.Bouncer
- UNLIMITED_MAX_COLUMNS_TO_MERGE - Static variable in interface org.apache.druid.segment.IndexMerger
- unmap(MappedByteBuffer) - Static method in class org.apache.druid.java.util.common.ByteBufferUtils
-
Un-maps the given memory mapped file
- UnnestColumnValueSelectorCursor - Class in org.apache.druid.segment
-
The cursor to help unnest MVDs without dictionary encoding and ARRAY type selectors.
- UnnestColumnValueSelectorCursor(Cursor, ColumnSelectorFactory, VirtualColumn, String) - Constructor for class org.apache.druid.segment.UnnestColumnValueSelectorCursor
- UnnestDataSource - Class in org.apache.druid.query
-
The data source for representing an unnest operation.
- UnnestDimensionCursor - Class in org.apache.druid.segment
-
The cursor to help unnest MVDs with dictionary encoding.
- UnnestDimensionCursor(Cursor, ColumnSelectorFactory, VirtualColumn, String) - Constructor for class org.apache.druid.segment.UnnestDimensionCursor
- UnnestStorageAdapter - Class in org.apache.druid.segment
-
This class serves as the Storage Adapter for the Unnest Segment and is responsible for creating the cursors If the column is dictionary encoded it creates
UnnestDimensionCursor
elseUnnestColumnValueSelectorCursor
These cursors help navigate the segments for these cases - UnnestStorageAdapter(StorageAdapter, VirtualColumn, DimFilter) - Constructor for class org.apache.druid.segment.UnnestStorageAdapter
- UNPARSEABLE - Static variable in interface org.apache.druid.segment.incremental.RowIngestionMeters
- UnparseableColumnsParseException - Exception in org.apache.druid.java.util.common.parsers
-
This type of ParseException is meant to be used within ingestion to hold parse exception information for rows that were partially parseable but had one or more unparseable columns, such as when passing a non-numeric value to a numeric column.
- UnparseableColumnsParseException(String, List<String>, boolean, String, Object...) - Constructor for exception org.apache.druid.java.util.common.parsers.UnparseableColumnsParseException
- unprefix(String) - Method in class org.apache.druid.segment.join.JoinableClause
-
Removes our prefix from "columnName".
- unprefix(String, String) - Static method in class org.apache.druid.segment.join.JoinPrefixUtils
-
Removes the prefix on
columnName
. - unregisterSerde(String) - Static method in class org.apache.druid.segment.serde.ComplexMetrics
-
Unregister a serde name -> ComplexMetricSerde mapping.
- UnsafeUtils - Class in org.apache.druid.java.util.common
-
This utiliy class enables runtime access to sun.misc.Unsafe using reflection, since Unsafe may not be directly accessible in newer JDK versions
- UnsafeUtils() - Constructor for class org.apache.druid.java.util.common.UnsafeUtils
- unset() - Method in class org.apache.druid.segment.incremental.IncrementalIndex.InputRowHolder
- UnstableApi - Annotation Type in org.apache.druid.guice.annotations
-
Signifies that the annotated entity is an unstable API for extension authors.
- UNSUPPORTED - org.apache.druid.error.DruidException.Category
-
Indicates some unsupported behavior was requested.
- UNSUPPORTED - org.apache.druid.query.QueryException.FailType
- UNSUPPORTED_OPERATION_ERROR_CODE - Static variable in exception org.apache.druid.query.QueryException
- UnsupportedColumnTypeException - Exception in org.apache.druid.frame.write
- UnsupportedColumnTypeException(String, ColumnType) - Constructor for exception org.apache.druid.frame.write.UnsupportedColumnTypeException
- UnsupportedColumnTypeFrameColumnReader - Class in org.apache.druid.frame.read.columnar
-
Dummy reader for unsupported types.
- unwrap(Object) - Method in class org.apache.druid.java.util.common.parsers.FlattenerJsonProvider
- unwrap(Object) - Static method in class org.apache.druid.segment.nested.StructuredData
- unzip(ByteSource, File, Predicate<Throwable>, boolean) - Static method in class org.apache.druid.utils.CompressionUtils
-
Unzip the byteSource to the output directory.
- unzip(File, File) - Static method in class org.apache.druid.utils.CompressionUtils
-
Unzip the pulled file to an output directory.
- unzip(InputStream, File) - Static method in class org.apache.druid.utils.CompressionUtils
-
Unzip from the input stream to the output directory, using the entry's file name as the file name in the output directory.
- UOE - Exception in org.apache.druid.java.util.common
- UOE(String, Object...) - Constructor for exception org.apache.druid.java.util.common.UOE
- update(double) - 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
- update(DoubleMeanHolder) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanHolder
- 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
- 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
- updateHeapIndexForOffset(int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper.BufferGrouperOffsetHeapIndexUpdater
- updateResults(PooledTopNAlgorithm.PooledTopNParams, int[], BufferAggregator[], TopNResultBuilder) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm
- updateResults(TopNParams, int[], Map<Object, Aggregator[]>, TopNResultBuilder) - Method in class org.apache.druid.query.topn.TimeExtractionTopNAlgorithm
- updateResults(TopNParams, Aggregator[][], TopNColumnAggregatesProcessor, TopNResultBuilder) - Method in class org.apache.druid.query.topn.HeapBasedTopNAlgorithm
- 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
-
Used by
HeapBasedTopNAlgorithm
. - updateResults(Parameters, DimValSelector, DimValAggregateStore, TopNResultBuilder) - Method in class org.apache.druid.query.topn.BaseTopNAlgorithm
- 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, DimensionSelector, SearchQuerySpec, int, Object2IntRBTreeMap<SearchHit>) - Method in class org.apache.druid.query.search.SearchQueryRunner.StringSearchColumnSelectorStrategy
- 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.
- UpperExtractionFn - Class in org.apache.druid.query.extraction
- UpperExtractionFn(String) - Constructor for class org.apache.druid.query.extraction.UpperExtractionFn
- UpperFunc() - Constructor for class org.apache.druid.math.expr.Function.UpperFunc
- URI - org.apache.druid.data.input.impl.systemfield.SystemField
- URIDataPuller - Interface in org.apache.druid.segment.loading
-
A URIDataPuller has handlings for URI based data
- UriExtractor - Interface in org.apache.druid.java.util.emitter.core
- URIs - Class in org.apache.druid.java.util.common
- urlDecode(String) - Static method in class org.apache.druid.java.util.common.StringUtils
- urlEncode(String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Encodes a String in application/x-www-form-urlencoded format, with one exception: "+" in the encoded form is replaced with "%20".
- 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
- USE_NESTED_FOR_UNKNOWN_TYPE_IN_SUBQUERY - Static variable in class org.apache.druid.query.QueryContexts
- USE_RESULT_LEVEL_CACHE_KEY - Static variable in class org.apache.druid.query.QueryContexts
- UsedByJUnitParamsRunner - Annotation Type in org.apache.druid.annotations
-
Annotating test methods, which names have "parametersFor" prefix, and used by
JUnitParamsRunner
, see https://github.com/Pragmatists/junitparams/wiki/Quickstart. - useDictionaryEncodedSelector(ColumnCapabilities) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.GroupByVectorColumnProcessorFactory
-
The group by engine vector processor has a more relaxed approach to choosing to use a dictionary encoded string selector over an object selector than some of the other
VectorColumnProcessorFactory
implementations. - useDictionaryEncodedSelector(ColumnCapabilities) - Method in interface org.apache.druid.segment.VectorColumnProcessorFactory
-
The processor factory can influence the decision on whether or not to prefer a dictionary encoded column value selector over a an object selector by examining the
ColumnCapabilities
. - UsedInGeneratedCode - Annotation Type in org.apache.druid.annotations
-
Annotation for members, which are used in generated code (e.
- UseIndexesStrategy - Class in org.apache.druid.query.search
- UseIndexesStrategy.IndexOnlyExecutor - Class in org.apache.druid.query.search
- useListBasedInputRows() - Method in class org.apache.druid.data.input.impl.FlatTextInputFormat
-
Whether this format can use
ListBasedInputRow
, which are preferred overMapBasedInputRow
when possible. - useMaxMemoryEstimates - Variable in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- useNonRootGenerationPartitionSpace() - Method in class org.apache.druid.timeline.partition.NumberedOverwritePartialShardSpec
- useNonRootGenerationPartitionSpace() - Method in interface org.apache.druid.timeline.partition.PartialShardSpec
-
Returns true if this partialShardSpec needs a partitionId of a non-root generation.
- USER - org.apache.druid.error.DruidException.Persona
-
Represents the end-user, a persona who is issuing queries to the Druid Query APIs
- USER_ERROR - org.apache.druid.query.QueryException.FailType
- useSchemaDiscovery() - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- useSchemaDiscovery(boolean) - Method in class org.apache.druid.data.input.impl.DimensionsSpec.Builder
- usesDotNotation() - Method in class org.apache.druid.frame.util.SettableLongVirtualColumn
- usesDotNotation() - Method in class org.apache.druid.segment.virtual.ExpressionVirtualColumn
- usesDotNotation() - Method in class org.apache.druid.segment.virtual.FallbackVirtualColumn
- usesDotNotation() - Method in class org.apache.druid.segment.virtual.ListFilteredVirtualColumn
- usesDotNotation() - Method in class org.apache.druid.segment.virtual.NestedFieldVirtualColumn
- usesDotNotation() - Method in interface org.apache.druid.segment.VirtualColumn
-
Indicates that this virtual column can be referenced with dot notation.
- useStrictBooleans() - Static method in class org.apache.druid.math.expr.ExpressionProcessing
-
All boolean expressions are
ExpressionType.LONG
- useThreeValueLogic() - Static method in class org.apache.druid.common.config.NullHandling
-
Whether filtering uses 3-valued logic.
- usingDefaultInterval(boolean) - Method in class org.apache.druid.query.Druids.SegmentMetadataQueryBuilder
- usrTime() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
- usrTime(int) - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
- usrTimes() - Method in class org.apache.druid.java.util.metrics.cgroups.CpuAcct.CpuAcctMetric
- utc(long) - Static method in class org.apache.druid.java.util.common.DateTimes
- utc(long, long) - Static method in class org.apache.druid.java.util.common.Intervals
- UTF16LE - org.apache.druid.java.util.common.StringEncoding
- Utf8() - Constructor for class org.apache.druid.segment.column.StringEncodingStrategy.Utf8
- UTF8 - org.apache.druid.java.util.common.StringEncoding
- UTF8 - Static variable in interface org.apache.druid.segment.column.StringEncodingStrategy
- UTF8_CHARSET - Static variable in class org.apache.druid.java.util.common.StringUtils
-
Deprecated.
- UTF8_ID - Static variable in interface org.apache.druid.segment.column.StringEncodingStrategy
- UTF8_STRATEGY - Static variable in class org.apache.druid.segment.data.GenericIndexed
-
An ObjectStrategy that returns a big-endian ByteBuffer pointing to original data.
- UTF8_STRING - Static variable in class org.apache.druid.java.util.common.StringUtils
- utf8Base64(String) - Static method in class org.apache.druid.java.util.common.StringUtils
-
Convert an input to base 64 and return the utf8 string of that byte array
- utf8Comparator() - Static method in class org.apache.druid.java.util.common.ByteBufferUtils
-
Comparator that compares two
ByteBuffer
using ordering consistent withString.compareTo(String)
. - Utf8ToStringIndexed(Indexed<ByteBuffer>) - Constructor for class org.apache.druid.segment.column.StringEncodingStrategies.Utf8ToStringIndexed
- Utf8ValueSetIndexes - Interface in org.apache.druid.segment.index.semantic
-
Construct a
BitmapColumnIndex
for a set of utf8 byte values which might be present in the column. - Utils - Class in org.apache.druid.java.util.common.collect
- Utils() - Constructor for class org.apache.druid.java.util.common.collect.Utils
- UUID_DELIM - Static variable in class org.apache.druid.common.utils.UUIDUtils
- UUIDUtils - Class in org.apache.druid.common.utils
- UUIDUtils() - Constructor for class org.apache.druid.common.utils.UUIDUtils
V
- V0 - Static variable in class org.apache.druid.segment.data.FrontCodedIndexed
- V0 - Static variable in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- V1 - Static variable in class org.apache.druid.segment.data.FrontCodedIndexed
- 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
- validate() - Method in class org.apache.druid.segment.incremental.AppendableIndexBuilder
- validateAndGetPath(String, String) - Static method in class org.apache.druid.storage.local.LocalFileExportStorageProvider
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayConstructorFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayContainsFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayLengthFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayOverlapFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayScalarFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraysFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArraySliceFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ArrayToMultiValueStringFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.BivariateFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.CaseSearchedFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.CaseSimpleFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.CoalesceFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ConcatFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ConditionFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsDistinctFromFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsFalseFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotDistinctFromFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotFalseFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotNullFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNotTrueFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsNullFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.IsTrueFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.LowerFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.LpadFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.MultiValueStringHarmonizeNullsFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.MultiValueStringToArrayFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.NvlFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ParseLong
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.Pi
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ReduceFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.ReplaceFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.Round
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.RpadFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.SizeFormatFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.StringFormatFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.StringToArrayFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.StrlenFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.StrposFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.SubMonthFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.SubstringFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.TimestampFromEpochFunc
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.UnivariateFunction
- validateArguments(List<Expr>) - Method in class org.apache.druid.math.expr.Function.UpperFunc
- validateArguments(List<Expr>) - Method in interface org.apache.druid.math.expr.Function
-
Validate function arguments.
- validateArguments(LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianFoldFunction
- validateArguments(LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianMapFunction
- validateArguments(LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.FilterFunction
- validateArguments(LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.FoldFunction
- validateArguments(LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.MapFunction
- validateArguments(LambdaExpr, List<Expr>) - Method in class org.apache.druid.math.expr.ApplyFunction.MatchFunction
- validateArguments(LambdaExpr, List<Expr>) - Method in interface org.apache.druid.math.expr.ApplyFunction
-
Validate function arguments.
- validateBufferCapacity(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedBufferHashGrouper
- validateConstant(Expr) - Static method in class org.apache.druid.math.expr.InputBindings
-
Empty binding that throw a
UOE
if anything attempts to lookup an identifier type or value - validateEquivalent(OperatorFactory) - Method in class org.apache.druid.query.operator.NaivePartitioningOperatorFactory
- validateEquivalent(OperatorFactory) - Method in class org.apache.druid.query.operator.NaiveSortOperatorFactory
- validateEquivalent(OperatorFactory) - Method in interface org.apache.druid.query.operator.OperatorFactory
-
Validates the equivalence of Operators.
- validateEquivalent(OperatorFactory) - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- validateEquivalent(OperatorFactory) - Method in class org.apache.druid.query.operator.window.WindowOperatorFactory
- validateEquivalent(Processor) - Method in class org.apache.druid.query.operator.window.ComposingProcessor
- validateEquivalent(Processor) - Method in interface org.apache.druid.query.operator.window.Processor
-
Validates the equivalence of the Processors.
- validateEquivalent(Processor) - Method in class org.apache.druid.query.operator.window.ranking.WindowPercentileProcessor
- validateEquivalent(Processor) - Method in class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- validateEquivalent(Processor) - Method in class org.apache.druid.query.operator.window.ranking.WindowRankProcessor
- validateEquivalent(Processor) - Method in class org.apache.druid.query.operator.window.ranking.WindowRowNumberProcessor
- validateEquivalent(Processor) - Method in class org.apache.druid.query.operator.window.value.WindowOffsetProcessor
- validateEquivalent(Processor) - Method in class org.apache.druid.query.operator.window.value.WindowValueProcessorBase
- validateEquivalent(Processor) - Method in class org.apache.druid.query.operator.window.WindowFramedAggregateProcessor
- validateExpr(Expr, Expr.BindingAnalysis) - Static method in class org.apache.druid.math.expr.Parser
-
Validate that an expression uses input bindings in a type consistent manner.
- validateFields(Iterable<String>) - Static method in class org.apache.druid.java.util.common.parsers.ParserUtils
- validateId(String, String) - Static method in class org.apache.druid.common.utils.IdUtils
- validateNestedFormatVersion(Integer) - Static method in class org.apache.druid.segment.DefaultColumnFormatConfig
- validatePrefix(String) - Static method in class org.apache.druid.segment.join.JoinPrefixUtils
-
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
- validateUriScheme(String, URI) - Static method in class org.apache.druid.data.input.impl.CloudObjectLocation
- validateVersion(byte) - Static method in class org.apache.druid.segment.data.FrontCodedIndexed
- validateZipOutputFile(String, File, File) - Static method in class org.apache.druid.utils.CompressionUtils
- validationFailed(String, Object...) - Method in interface org.apache.druid.math.expr.NamedFunction
-
Helper method for creating a
ExpressionValidationException
with the specified reason - validationFailed(Throwable, String, Object...) - Method in interface org.apache.druid.math.expr.NamedFunction
- validationHelperCheckAnyOfArgumentCount(List<Expr>, int...) - Method in interface org.apache.druid.math.expr.NamedFunction
-
Helper method for implementors performing validation to check if argument count is any of specified counts
- validationHelperCheckArgIsLiteral(Expr, String) - Method in interface org.apache.druid.math.expr.NamedFunction
-
Helper method for implementors performing validation to check that an argument is a literal
- validationHelperCheckArgumentCount(List<Expr>, int) - Method in interface org.apache.druid.math.expr.NamedFunction
-
Helper method for implementors performing validation to check if the argument count is expected
- validationHelperCheckArgumentCount(LambdaExpr, List<Expr>, int) - Method in interface org.apache.druid.math.expr.NamedFunction
-
Helper method for implementors performing validation to check that the argument list is some expected size.
- validationHelperCheckArgumentRange(List<Expr>, int, int) - Method in interface org.apache.druid.math.expr.NamedFunction
- validationHelperCheckLambaArgumentCount(LambdaExpr, List<Expr>) - Method in interface org.apache.druid.math.expr.NamedFunction
-
Helper method for implementors performing validation to check that the
LambdaExpr.identifierCount()
matches the number of arguments being passed to it - validationHelperCheckMinArgumentCount(List<Expr>, int) - Method in interface org.apache.druid.math.expr.NamedFunction
-
Helper method for implementors performing validation to check if there are at least as many arguments as specified
- validationHelperCheckMinArgumentCount(LambdaExpr, List<Expr>, int) - Method in interface org.apache.druid.math.expr.NamedFunction
-
Helper method for implementors performing validation to check that the argument list is at least some expected size.
- value() - Method in annotation type org.apache.druid.annotations.SuppressFBWarnings
-
The set of FindBugs warnings that are to be suppressed in annotated element.
- value() - Method in class org.apache.druid.frame.processor.ReturnOrAwait
-
The returned result.
- value() - Method in class org.apache.druid.math.expr.ExprEval
- value() - Method in class org.apache.druid.query.groupby.epinephelinae.column.MemoryFootprint
- value(String) - Method in class org.apache.druid.frame.write.InvalidNullByteException.Builder
- value(R) - Static method in class org.apache.druid.java.util.common.Either
- VALUE_COLUMN - Static variable in class org.apache.druid.segment.join.lookup.LookupColumnSelectorFactory
- VALUE_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- VALUE_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- VALUE_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- VALUE_COMPARATOR - Static variable in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- VALUE_OFFSET - Static variable in class org.apache.druid.query.aggregation.firstlast.FirstLastVectorAggregator
- VALUE_OFFSET - Static variable in class org.apache.druid.segment.column.TypeStrategies
- VALUE_TERMINATOR - Static variable in class org.apache.druid.frame.field.StringFieldWriter
- ValueDictionary - Class in org.apache.druid.segment.nested
-
Used by
AutoTypeColumnIndexer
to build the value dictionary, which can be converted into aSortedValueDictionary
to sort and write out the values to a segment withValueDictionary.getSortedCollector()
. - ValueDictionary() - Constructor for class org.apache.druid.segment.nested.ValueDictionary
- ValueIndexes - Interface in org.apache.druid.segment.index.semantic
-
Construct a
BitmapColumnIndex
for a specific value which might be present in the column. - valueMatcher(ColumnSelectorFactory, Offset, boolean) - Method in interface org.apache.druid.query.filter.FilterBundle.MatcherBundle
- valueMatcher(ColumnSelectorFactory, Offset, boolean) - Method in class org.apache.druid.query.filter.FilterBundle.SimpleMatcherBundle
- 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(int) - Static method in class org.apache.druid.java.util.common.HumanReadableBytes
- valueOf(long) - Static method in class org.apache.druid.java.util.common.HumanReadableBytes
- valueOf(String) - Static method in enum org.apache.druid.collections.spatial.search.RadiusBound.RadiusUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.data.input.impl.systemfield.SystemField
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.error.DruidException.Category
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.error.DruidException.Persona
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.frame.file.FrameFile.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.frame.FrameType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.frame.key.KeyOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.indexer.IngestionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.indexer.partitions.SecondaryPartitionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.indexer.RunnerTaskState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.indexer.TaskState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.concurrent.ScheduledExecutors.Signal
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.FileUtils.LinkOrCopyResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.granularity.Granularity.Formatter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.granularity.GranularityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.HumanReadableBytes.UnitSystem
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.lifecycle.Lifecycle.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser.FlatTextFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.parsers.JSONPathFieldType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.common.StringEncoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.emitter.core.BatchingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.emitter.core.ContentEncoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.emitter.core.LoggingEmitter.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.emitter.service.AlertEvent.Severity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.java.util.http.client.HttpClientConfig.CompressionCodec
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.math.expr.ExprType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.metadata.TaskLookup.TaskLookupType
-
Returns the enum constant of this type with the specified name.
- 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.ExecutionMode
-
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.DruidPredicateMatch
-
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.filter.RangeFilter.RangeType
-
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.AggregatorMergeStrategy
-
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.operator.ColumnWithDirection.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.query.operator.Operator.Signal
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.query.operator.window.WindowFrame.PeerType
-
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.QueryException.FailType
-
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.column.RowSignature.Finalization
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.segment.column.ValueType
-
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.filter.ConstantMatcherType
-
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.serde.DictionaryEncodedColumnPartSerde.Feature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.VERSION
-
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.
- valueOf(String) - Static method in enum org.apache.druid.timeline.LogicalSegment.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.timeline.partition.HashPartitionFunction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.timeline.Partitions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.druid.utils.CompressionUtils.Format
-
Returns the enum constant of this type with the specified name.
- valueOrDefault() - Method in class org.apache.druid.math.expr.ExprEval
- valueOrDefault(Boolean, boolean) - Static method in class org.apache.druid.common.config.Configs
-
Returns the given
value
if it is not null, otherwise returns thedefaultValue
. - valueOrDefault(Integer, int) - Static method in class org.apache.druid.common.config.Configs
-
Returns the given
value
if it is not null, otherwise returns thedefaultValue
. - valueOrDefault(Long, long) - Static method in class org.apache.druid.common.config.Configs
-
Returns the given
value
if it is not null, otherwise returns thedefaultValue
. - valueOrDefault(T, T) - Static method in class org.apache.druid.common.config.Configs
-
Returns the given
value
if it is not null, otherwise returns thedefaultValue
. - valueOrThrow() - Method in class org.apache.druid.java.util.common.Either
-
If this Either represents a value, returns it.
- values() - Static method in enum org.apache.druid.collections.spatial.search.RadiusBound.RadiusUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.data.input.impl.DimensionSchema.MultiValueHandling
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.data.input.impl.systemfield.SystemField
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.error.DruidException.Category
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.error.DruidException.Persona
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.frame.file.FrameFile.Flag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.frame.FrameType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.frame.key.KeyOrder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.indexer.IngestionState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.indexer.partitions.SecondaryPartitionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.indexer.RunnerTaskState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.indexer.TaskState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.concurrent.ScheduledExecutors.Signal
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.FileUtils.LinkOrCopyResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.granularity.Granularity.Formatter
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.granularity.GranularityType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.HumanReadableBytes.UnitSystem
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.lifecycle.Lifecycle.Stage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.parsers.AbstractFlatTextFormatParser.FlatTextFormat
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.parsers.JSONPathFieldType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.common.StringEncoding
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.emitter.core.BatchingStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.emitter.core.ContentEncoding
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.emitter.core.LoggingEmitter.Level
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.emitter.service.AlertEvent.Severity
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.java.util.http.client.HttpClientConfig.CompressionCodec
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.math.expr.ExprType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.druid.math.expr.vector.ExprEvalDoubleVector
- values() - Method in class org.apache.druid.math.expr.vector.ExprEvalVector
- values() - Static method in enum org.apache.druid.metadata.TaskLookup.TaskLookupType
-
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.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.ExecutionMode
-
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.DruidPredicateMatch
-
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.filter.RangeFilter.RangeType
-
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.AggregatorMergeStrategy
-
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.operator.ColumnWithDirection.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.operator.Operator.Signal
-
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.operator.window.WindowFrame.PeerType
-
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.QueryException.FailType
-
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.column.RowSignature.Finalization
-
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.ValueType
-
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.filter.ConstantMatcherType
-
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.serde.DictionaryEncodedColumnPartSerde.Feature
-
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.serde.DictionaryEncodedColumnPartSerde.VERSION
-
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.
- values() - Static method in enum org.apache.druid.timeline.LogicalSegment.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.timeline.partition.HashPartitionFunction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.timeline.Partitions
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.druid.utils.CompressionUtils.Format
-
Returns an array containing the constants of this enum type, in the order they are declared.
- ValueSetIndexes - Interface in org.apache.druid.segment.index.semantic
-
Construct a
BitmapColumnIndex
for a set of values which might be present in the column. - ValueSetIndexes.BaseValueSetIndexesFromIterable - Class in org.apache.druid.segment.index.semantic
- valueSize() - Method in class org.apache.druid.query.groupby.epinephelinae.collection.MemoryOpenHashTable
-
Returns the size of values, in bytes.
- valueSize(boolean) - Static method in class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- valueSize(boolean) - Static method in class org.apache.druid.frame.write.columnar.FloatFrameMaker
- valueSize(boolean) - Static method in class org.apache.druid.frame.write.columnar.LongFrameMaker
- ValuesSet() - Constructor for class org.apache.druid.query.filter.InDimFilter.ValuesSet
- ValueType - Enum in org.apache.druid.segment.column
-
This enumeration defines the high level classification of the Druid type system, used by
ColumnType
to indicate the type of data stored in columns and produced by expressions and aggregations, used to allow query processing engine algorithms to compute results, used to compute query result row signatures, and all other type needs. - 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
- VariantArrayFieldColumnWriter - Class in org.apache.druid.segment.nested
-
Nested field writer for array type columns of
NestedDataColumnSerializer
. - VariantArrayFieldColumnWriter(String, String, SegmentWriteOutMedium, IndexSpec, DictionaryIdLookup) - Constructor for class org.apache.druid.segment.nested.VariantArrayFieldColumnWriter
- VariantColumn<TStringDictionary extends Indexed<ByteBuffer>> - Class in org.apache.druid.segment.nested
-
NestedCommonFormatColumn
for single type array columns, and mixed type columns. - VariantColumn(TStringDictionary, FixedIndexed<Long>, FixedIndexed<Double>, FrontCodedIntArrayIndexed, ColumnarInts, ImmutableBitmap, ColumnType, Byte) - Constructor for class org.apache.druid.segment.nested.VariantColumn
- VariantColumn.VariantVectorObjectSelector - Class in org.apache.druid.segment.nested
-
Make a
VectorObjectSelector
for a dictionary encoded column that coerces mixed types to a common type - VariantColumnAndIndexSupplier - Class in org.apache.druid.segment.nested
- VariantColumnAndIndexSupplier(ColumnType, Byte, Supplier<? extends Indexed<ByteBuffer>>, Supplier<FixedIndexed<Long>>, Supplier<FixedIndexed<Double>>, Supplier<FrontCodedIntArrayIndexed>, Supplier<FixedIndexed<Integer>>, Supplier<ColumnarInts>, GenericIndexed<ImmutableBitmap>, GenericIndexed<ImmutableBitmap>, BitmapFactory) - Constructor for class org.apache.druid.segment.nested.VariantColumnAndIndexSupplier
- VariantColumnSerializer - Class in org.apache.druid.segment.nested
-
Serializer for a
NestedCommonFormatColumn
for single type arrays and mixed type columns, but not columns with nested data. - VariantColumnSerializer(String, ColumnType, Byte, IndexSpec, SegmentWriteOutMedium, Closer) - Constructor for class org.apache.druid.segment.nested.VariantColumnSerializer
- VariantFieldColumnWriter - Class in org.apache.druid.segment.nested
-
Nested field writer for mixed type scalar or array columns of
NestedDataColumnSerializer
. - VariantFieldColumnWriter(String, String, SegmentWriteOutMedium, IndexSpec, DictionaryIdLookup) - Constructor for class org.apache.druid.segment.nested.VariantFieldColumnWriter
- VariantVectorObjectSelector(ReadableVectorOffset, ColumnarInts, FrontCodedIntArrayIndexed, ExpressionType, int) - Constructor for class org.apache.druid.segment.nested.VariantColumn.VariantVectorObjectSelector
- VByte - Class in org.apache.druid.segment.data
- VByte() - Constructor for class org.apache.druid.segment.data.VByte
- 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
-
A class that comes from
VectorCursor.getColumnSelectorFactory()
and is used to create vector selectors. - VectorComparisonProcessors - Class in org.apache.druid.math.expr.vector
- VectorCopier - Interface in org.apache.druid.query.rowsandcols.column
-
A semantic interface for use with
Column
objects. - 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
-
Contains logic to process a groupBy query on a single
StorageAdapter
in a vectorized manner. - VectorGrouper - Interface in org.apache.druid.query.groupby.epinephelinae
-
Like a
Grouper
, but vectorized. - VECTORIZABLE - org.apache.druid.segment.virtual.ExpressionPlan.Trait
-
expression is vectorizable
- 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.
- vectorMatcher(VectorColumnSelectorFactory, ReadableVectorOffset) - Method in interface org.apache.druid.query.filter.FilterBundle.MatcherBundle
- vectorMatcher(VectorColumnSelectorFactory, ReadableVectorOffset) - Method in class org.apache.druid.query.filter.FilterBundle.SimpleMatcherBundle
- VectorMathProcessors - Class in org.apache.druid.math.expr.vector
- vectorObjectSelector(VectorSizeInspector, Object) - Static method in class org.apache.druid.segment.vector.ConstantVectorSelectors
- VectorObjectSelector - Interface in org.apache.druid.segment.vector
-
Vectorized object selector.
- VectorOffset - Interface in org.apache.druid.segment.vector
-
The movable version of ReadableVectorOffset.
- VectorProcessors - Class in org.apache.druid.math.expr.vector
- 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.
- VectorStringProcessors - Class in org.apache.druid.math.expr.vector
- VectorStringProcessors() - Constructor for class org.apache.druid.math.expr.vector.VectorStringProcessors
- 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.
- verifyClazzIsConfigurable(ObjectMapper, Class<T>, Class<? extends T>) - Static method in class org.apache.druid.guice.JsonConfigurator
- verifyMaxQueryTimeout(long) - Method in class org.apache.druid.query.QueryContext
- verifyMaxScatterGatherBytes(long) - Method in class org.apache.druid.query.QueryContext
- verifyOrderByForNativeExecution(ScanQuery) - Static method in class org.apache.druid.query.scan.ScanQuery
-
Verifies that the ordering of a query is solely determined by
ScanQuery.getTimeOrder()
. - 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
- verifySortColumns(List<KeyColumn>, RowSignature) - Static method in class org.apache.druid.frame.write.FrameWriterUtils
-
Verifies whether the provided sortColumns are all sortable, and are a prefix of the signature.
- version - Variable in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- version() - Method in enum org.apache.druid.frame.FrameType
- version() - Method in class org.apache.druid.segment.join.table.BroadcastSegmentIndexedTable
- version() - Method in class org.apache.druid.segment.join.table.FrameBasedIndexedTable
- 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(String) - Method in class org.apache.druid.timeline.DataSegment.Builder
- VERSION - Static variable in class org.apache.druid.hll.VersionOneHyperLogLogCollector
-
Header: Byte 0: version Byte 1: registerOffset Byte 2-3: numNonZeroRegisters Byte 4: maxOverflowValue Byte 5-6: maxOverflowRegister
- VERSION - Static variable in class org.apache.druid.java.util.emitter.service.SegmentMetadataEvent
- VERSION - Static variable in class org.apache.druid.query.ordering.StringComparators
- VERSION - Static variable in class org.apache.druid.segment.data.CompressedBlockReader
- 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.CompressedVariableSizedBlobColumnSupplier
- VERSION - Static variable in class org.apache.druid.segment.data.CompressedVSizeColumnarIntsSupplier
- VERSION - Static variable in class org.apache.druid.segment.data.EncodedStringDictionaryWriter
- VERSION - Static variable in class org.apache.druid.segment.data.V3CompressedVSizeColumnarMultiIntsSupplier
- VERSION - Static variable in class org.apache.druid.segment.data.VSizeColumnarInts
- 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
- VersionedIntervalTimeline<VersionType,ObjectType extends Overshadowable<ObjectType>> - Class in org.apache.druid.timeline
-
VersionedIntervalTimeline is a data structure that manages objects on a specific timeline.
- VersionedIntervalTimeline(Comparator<? super VersionType>) - Constructor for class org.apache.druid.timeline.VersionedIntervalTimeline
- VersionedIntervalTimeline(Comparator<? super VersionType>, boolean) - Constructor for class org.apache.druid.timeline.VersionedIntervalTimeline
- VersionedIntervalTimeline.PartitionChunkEntry<VersionType,ObjectType> - Class in org.apache.druid.timeline
-
Stores a
PartitionChunk
for a given interval and version. - VersionedIntervalTimeline.TimelineEntry - Class in org.apache.druid.timeline
- VersionOneHyperLogLogCollector - Class in org.apache.druid.hll
- VersionZeroHyperLogLogCollector - Class in org.apache.druid.hll
-
Deprecated.
- VirtualColumn - Interface in org.apache.druid.segment
-
Virtual columns are "views" created over a
ColumnSelectorFactory
orColumnSelector
. - VirtualColumnCacheHelper - Class in org.apache.druid.segment.virtual
- virtualColumns - Variable in class org.apache.druid.segment.virtual.VirtualizedColumnInspector
- virtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- virtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- virtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- virtualColumns(VirtualColumn...) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- virtualColumns(VirtualColumns) - Method in class org.apache.druid.query.Druids.ScanQueryBuilder
- virtualColumns(VirtualColumns) - Method in class org.apache.druid.query.Druids.SearchQueryBuilder
- virtualColumns(VirtualColumns) - Method in class org.apache.druid.query.Druids.TimeseriesQueryBuilder
- virtualColumns(VirtualColumns) - Method in class org.apache.druid.query.topn.TopNQueryBuilder
- VirtualColumns - Class in org.apache.druid.segment
-
Class allowing lookup and usage of virtual columns.
- VirtualColumns.JsonIncludeFilter - Class in org.apache.druid.segment
-
JsonInclude
filter forgetVirtualColumns()
. - VirtualizedColumnInspector - Class in org.apache.druid.segment.virtual
-
Provides
ColumnCapabilities
for both virtual and non-virtual columns by building on top of another baseColumnInspector
. - VirtualizedColumnInspector(ColumnInspector, VirtualColumns) - Constructor for class org.apache.druid.segment.virtual.VirtualizedColumnInspector
- VirtualizedColumnSelectorFactory - Class in org.apache.druid.segment.virtual
-
ColumnSelectorFactory
which can create selectors for both virtual and non-virtual columns - VirtualizedColumnSelectorFactory(ColumnSelectorFactory, VirtualColumns) - Constructor for class org.apache.druid.segment.virtual.VirtualizedColumnSelectorFactory
- visit(String, boolean) - Method in interface org.apache.druid.query.monomorphicprocessing.RuntimeShapeInspector
- visit(String, Object) - 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. - visit(String, HotLoopCallee) - Method in interface org.apache.druid.query.monomorphicprocessing.RuntimeShapeInspector
- visit(String, T[]) - Method in interface org.apache.druid.query.monomorphicprocessing.RuntimeShapeInspector
- visit(Expr) - Method in interface org.apache.druid.math.expr.Expr.Shuttle
-
Provide the
Expr.Shuttle
with anExpr
to inspect and potentially rewrite. - visit(Expr.Shuttle) - Method in interface org.apache.druid.math.expr.Expr
-
Programatically rewrite the
Expr
tree with aExpr.Shuttle
. - visit(Expr.Shuttle) - Method in class org.apache.druid.math.expr.ExprMacroTable.BaseMacroFunctionExpr
- visitAll(List<Expr>) - Method in interface org.apache.druid.math.expr.Expr.Shuttle
- visitErrorNode(ErrorNode) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
- visitTerminal(TerminalNode) - Method in class org.apache.druid.math.expr.antlr.ExprBaseListener
- VOCABULARY - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- VOCABULARY - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- 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
-
Unpack bitpacked long values from an underlying contiguous memory block
- VSizeLongSerde.LongSerializer - Interface in org.apache.druid.segment.data
W
- WAITING - org.apache.druid.indexer.RunnerTaskState
- warn(String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- warn(String, Throwable) - Method in class org.apache.druid.java.util.common.logger.Logger
-
Deprecated.
- warn(Throwable, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- warn(Marker, String, Object...) - Method in class org.apache.druid.java.util.common.logger.Logger
- WARN - org.apache.druid.java.util.emitter.core.LoggingEmitter.Level
- warnSegments(Collection<DataSegment>, String) - Method in class org.apache.druid.java.util.common.logger.Logger
- wasFound() - Method in class org.apache.druid.query.rowsandcols.util.FindResult
- watch(String, TypeReference<T>, T) - Method in class org.apache.druid.common.config.JacksonConfigManager
- watch(String, Class<? extends T>) - Method in class org.apache.druid.common.config.JacksonConfigManager
- watch(String, Class<? extends T>, T) - Method in class org.apache.druid.common.config.JacksonConfigManager
- watchConfig(String, ConfigSerde<T>) - Method in class org.apache.druid.common.config.ConfigManager
- WEEK - org.apache.druid.java.util.common.granularity.GranularityType
- WEEK - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- WEEK - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- WINDOW_OPERATOR - Static variable in interface org.apache.druid.query.Query
- WindowCumeDistProcessor - Class in org.apache.druid.query.operator.window.ranking
-
This Processor assumes that data has already been sorted for it.
- WindowCumeDistProcessor(List<String>, String) - Constructor for class org.apache.druid.query.operator.window.ranking.WindowCumeDistProcessor
- WindowDenseRankProcessor - Class in org.apache.druid.query.operator.window.ranking
-
This Processor assumes that data has already been sorted for it.
- WindowDenseRankProcessor(List<String>, String) - Constructor for class org.apache.druid.query.operator.window.ranking.WindowDenseRankProcessor
- WindowFirstProcessor - Class in org.apache.druid.query.operator.window.value
- WindowFirstProcessor(String, String) - Constructor for class org.apache.druid.query.operator.window.value.WindowFirstProcessor
- WindowFrame - Class in org.apache.druid.query.operator.window
- WindowFrame(WindowFrame.PeerType, boolean, int, boolean, int, List<ColumnWithDirection>) - Constructor for class org.apache.druid.query.operator.window.WindowFrame
- WindowFrame.PeerType - Enum in org.apache.druid.query.operator.window
- WindowFramedAggregateProcessor - Class in org.apache.druid.query.operator.window
- WindowFramedAggregateProcessor(WindowFrame, AggregatorFactory[]) - Constructor for class org.apache.druid.query.operator.window.WindowFramedAggregateProcessor
- WINDOWING_STRICT_VALIDATION - Static variable in class org.apache.druid.query.QueryContexts
- WindowLastProcessor - Class in org.apache.druid.query.operator.window.value
- WindowLastProcessor(String, String) - Constructor for class org.apache.druid.query.operator.window.value.WindowLastProcessor
- WindowOffsetProcessor - Class in org.apache.druid.query.operator.window.value
- WindowOffsetProcessor(String, String, int) - Constructor for class org.apache.druid.query.operator.window.value.WindowOffsetProcessor
- WindowOperatorFactory - Class in org.apache.druid.query.operator.window
- WindowOperatorFactory(Processor) - Constructor for class org.apache.druid.query.operator.window.WindowOperatorFactory
- WindowOperatorQuery - Class in org.apache.druid.query.operator
-
A query that can compute window functions on top of a completely in-memory inline datasource or query results.
- WindowOperatorQuery(DataSource, QuerySegmentSpec, Map<String, Object>, RowSignature, List<OperatorFactory>, List<OperatorFactory>) - Constructor for class org.apache.druid.query.operator.WindowOperatorQuery
- WindowOperatorQueryQueryRunnerFactory - Class in org.apache.druid.query.operator
- WindowOperatorQueryQueryRunnerFactory() - Constructor for class org.apache.druid.query.operator.WindowOperatorQueryQueryRunnerFactory
- WindowOperatorQueryQueryToolChest - Class in org.apache.druid.query.operator
- WindowOperatorQueryQueryToolChest() - Constructor for class org.apache.druid.query.operator.WindowOperatorQueryQueryToolChest
- WindowPercentileProcessor - Class in org.apache.druid.query.operator.window.ranking
- WindowPercentileProcessor(String, int) - Constructor for class org.apache.druid.query.operator.window.ranking.WindowPercentileProcessor
- WindowProcessorOperator - Class in org.apache.druid.query.operator
-
An Operator that applies a
Processor
, see javadoc on that interface for an explanation. - WindowProcessorOperator(Processor, Operator) - Constructor for class org.apache.druid.query.operator.WindowProcessorOperator
- WindowRankingProcessorBase - Class in org.apache.druid.query.operator.window.ranking
-
This Processor assumes that data has already been sorted for it.
- WindowRankingProcessorBase(List<String>, String) - Constructor for class org.apache.druid.query.operator.window.ranking.WindowRankingProcessorBase
- WindowRankProcessor - Class in org.apache.druid.query.operator.window.ranking
-
This Processor assumes that data has already been sorted for it.
- WindowRankProcessor(List<String>, String, boolean) - Constructor for class org.apache.druid.query.operator.window.ranking.WindowRankProcessor
- WindowRowNumberProcessor - Class in org.apache.druid.query.operator.window.ranking
- WindowRowNumberProcessor(String) - Constructor for class org.apache.druid.query.operator.window.ranking.WindowRowNumberProcessor
- WindowValueProcessorBase - Class in org.apache.druid.query.operator.window.value
- WindowValueProcessorBase(String, String) - Constructor for class org.apache.druid.query.operator.window.value.WindowValueProcessorBase
- WireTransferable - Interface in org.apache.druid.query.rowsandcols.semantic
- with(Expr) - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Combine with
Expr.BindingAnalysis
fromExpr.analyzeInputs()
- with(Expr.BindingAnalysis) - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Combine (union) another
Expr.BindingAnalysis
- withAccumulation(R2, BiFunction<R2, T, R2>) - Method in interface org.apache.druid.frame.processor.manager.ProcessorManager
-
Returns an
AccumulatingProcessorManager
that wraps this manager and accumulates a result, to be returned by itsProcessorManager.result()
method. - 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
- withArrayArguments(Set<Expr>) - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Add set of arguments as
Expr.BindingAnalysis.arrayVariables
that are *directly*IdentifierExpr
, else they are ignored. - withArrayInputs(boolean) - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Copy, setting if an expression has array inputs
- withArrayOutput(boolean) - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Copy, setting if an expression produces an array output
- withArrayProvider(TopNMetricSpecBuilder<int[]>) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
- withAtomicUpdateGroupSize(int) - Method in interface org.apache.druid.timeline.partition.OverwriteShardSpec
- withAtomicUpdateGroupSize(short) - Method in class org.apache.druid.timeline.partition.NumberedOverwriteShardSpec
- withAtomicUpdateGroupSize(short) - Method in interface org.apache.druid.timeline.partition.OverwriteShardSpec
- withBaggage(Closeable) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- withBaggage(FrameProcessor<T>, Closeable) - Static method in class org.apache.druid.frame.processor.FrameProcessors
- withBaggage(Sequence<T>, Closeable) - Static method in class org.apache.druid.java.util.common.guava.Sequences
- 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.
- withBinaryVersion(int) - Method in class org.apache.druid.timeline.DataSegment
- withBinding(String, Object) - Method in class org.apache.druid.math.expr.SettableObjectBinding
- withBitmapIndex(GenericIndexedWriter<ImmutableBitmap>) - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
- withBitmapSerdeFactory(BitmapSerdeFactory) - Method in class org.apache.druid.segment.IndexSpec.Builder
- 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
- withBitmapSerdeFactory(BitmapSerdeFactory) - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.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
- withByteOrder(ByteOrder) - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.SerializerBuilder
- withCapabilities(ColumnCapabilities) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- withCardinality(Integer) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- 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.FilteredDataSource
- withChildren(List<DataSource>) - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- 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
- withChildren(List<DataSource>) - Method in class org.apache.druid.query.UnnestDataSource
- withColumns(ColumnIncluderator) - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- withCompressionCodec(HttpClientConfig.CompressionCodec) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- withContext(String, Object) - Method in exception org.apache.druid.error.DruidException
- withContext(Map<String, String>) - Method in exception org.apache.druid.error.DruidException
- 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 class org.apache.druid.query.operator.WindowOperatorQuery
- 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.Queries
- withDelegate(Serializer) - 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(DictionaryWriter<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
- withDimensionCompression(CompressionStrategy) - Method in class org.apache.druid.segment.IndexSpec.Builder
- withDimensionExclusions(Set<String>) - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- withDimensions(List<String>) - Method in class org.apache.druid.timeline.DataSegment
- withDimensions(List<DimensionSchema>) - Method in class org.apache.druid.data.input.impl.DimensionsSpec
- 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.data.input.impl.CSVParseSpec
- withDimensionsSpec(DimensionsSpec) - Method in class org.apache.druid.data.input.impl.DelimitedParseSpec
- withDimensionsSpec(DimensionsSpec) - Method in class org.apache.druid.data.input.impl.JavaScriptParseSpec
- withDimensionsSpec(DimensionsSpec) - Method in class org.apache.druid.data.input.impl.JSONLowercaseParseSpec
-
Deprecated.
- withDimensionsSpec(DimensionsSpec) - Method in class org.apache.druid.data.input.impl.JSONParseSpec
- withDimensionsSpec(DimensionsSpec) - Method in class org.apache.druid.data.input.impl.ParseSpec
-
Deprecated.
- withDimensionsSpec(DimensionsSpec) - Method in class org.apache.druid.data.input.impl.RegexParseSpec
- withDimensionsSpec(DimensionsSpec) - Method in class org.apache.druid.data.input.impl.TimeAndDimsParseSpec
- 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(Object, ColumnType) - Method in class org.apache.druid.query.topn.DimValHolder.Builder
-
This method is called by
TopNResultBuilder.addEntry(java.lang.Object, java.lang.Object, java.lang.Object[])
to store query results. - withDuration(long) - Method in class org.apache.druid.indexer.TaskStatus
- withEagerInitialization(boolean) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- withEffect(Runnable, Executor) - Method in interface org.apache.druid.java.util.common.guava.Sequence
- withEffect(Sequence<T>, Runnable, Executor) - Static method in class org.apache.druid.java.util.common.guava.Sequences
- withEmptyBaggage(Iterator<T>) - Static method in class org.apache.druid.java.util.common.CloseableIterators
- withEmptyMetadata(CloseableIterator<T>) - Static method in interface org.apache.druid.java.util.common.parsers.CloseableIteratorWithMetadata
-
Creates an instance of CloseableIteratorWithMetadata from a
CloseableIterator
. - withEmptyProperties() - Method in class org.apache.druid.guice.StartupInjectorBuilder
- withEnforceLogicalType(boolean) - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.SerializerBuilder
- withErrorCode(String) - Method in class org.apache.druid.error.DruidException.DruidExceptionBuilder
- withErrorMessage(String) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- withErrorMessageAndResolvedHost(String) - Static method in exception org.apache.druid.query.QueryCapacityExceededException
-
This method sets hostName unlike constructors because this can be called in historicals while those constructors are only used in brokers.
- withExtensions() - Method in class org.apache.druid.guice.StartupInjectorBuilder
- withFinalizedAnalysisTypes(SegmentMetadataQueryConfig) - Method in class org.apache.druid.query.metadata.metadata.SegmentMetadataQuery
- withHasNulls(boolean) - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.SerializerBuilder
- withHttpProxyConfig(HttpClientProxyConfig) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- 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.frame.segment.FrameFilteredOffset
- 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
- withIndex(int) - Method in class org.apache.druid.math.expr.ApplyFunction.CartesianMapLambdaBinding
- withIndex(int) - Method in interface org.apache.druid.math.expr.ApplyFunction.IndexableMapLambdaObjectBinding
-
Update index position
- withIndex(int) - Method in class org.apache.druid.math.expr.ApplyFunction.MapLambdaBinding
- withInspector(Expr.InputBindingInspector) - Method in class org.apache.druid.math.expr.SettableObjectBinding
- withInterval(Interval) - Method in class org.apache.druid.timeline.SegmentId
- withJsonCompression(CompressionStrategy) - Method in class org.apache.druid.segment.IndexSpec.Builder
- withKeyDimensions(Set<String>) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
-
Replace the param
keyDimensions
with the new set of key dimensions - withLane(String) - Method in interface org.apache.druid.query.Query
- withLastCompactionState(CompactionState) - Method in class org.apache.druid.timeline.DataSegment
- withLimit(int) - Method in class org.apache.druid.query.search.SearchQuery
- withLimit(long) - Method in class org.apache.druid.query.scan.ScanQuery
- withLimitSpec(LimitSpec) - Method in class org.apache.druid.query.groupby.GroupByQuery
- withLineSplittable(boolean) - Method in class org.apache.druid.data.input.impl.JsonInputFormat
-
Create a new JsonInputFormat object based on the given parameter sub-classes may need to override this method to create an object with correct sub-class type
- withLineSplittable(InputFormat, boolean) - Static method in class org.apache.druid.data.input.impl.JsonInputFormat
-
If the provided format is
JsonInputFormat
, return a version withJsonInputFormat.withLineSplittable(boolean)
called. - withLoadSpec(Map<String, Object>) - Method in class org.apache.druid.timeline.DataSegment
- withLocation(TaskLocation) - Method in class org.apache.druid.indexer.TaskStatus
- withLogicalType(ColumnType) - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.SerializerBuilder
- withLongEncoding(CompressionFactory.LongEncodingStrategy) - Method in class org.apache.druid.segment.IndexSpec.Builder
- 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.Queries
- withMaxValue(Comparable<T>) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- withMessage(String, Object...) - Static method in exception org.apache.druid.query.ResourceLimitExceededException
- withMetricCompression(CompressionStrategy) - Method in class org.apache.druid.segment.IndexSpec.Builder
- withMetrics(List<String>) - Method in class org.apache.druid.timeline.DataSegment
- 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
- withMinTimestampIfAbsent(DateTime) - Method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
-
If
TaskLookup.CompleteTaskLookup.hasTaskCreatedTimeFilter()
, returns this instance. - withMinValue(Comparable<T>) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- withName(String) - Method in class org.apache.druid.query.aggregation.AggregatorFactory
-
Used in cases where we want to change the output name of the aggregator to something else.
- withName(String) - Method in class org.apache.druid.query.aggregation.any.DoubleAnyAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.any.FloatAnyAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.any.LongAnyAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.any.StringAnyAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.cardinality.CardinalityAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.CountAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.DoubleMaxAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.DoubleMinAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.DoubleSumAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.ExpressionLambdaAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.FilteredAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.first.DoubleFirstAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.first.FloatFirstAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.first.LongFirstAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.first.StringFirstFoldingAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.last.DoubleLastAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.last.FloatLastAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.last.LongLastAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.firstlast.last.StringLastFoldingAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.FloatMaxAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.FloatMinAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.FloatSumAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.GroupingAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.HistogramAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.hyperloglog.HyperUniquesAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.JavaScriptAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.LongMaxAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.LongMinAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.LongSumAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.mean.DoubleMeanAggregatorFactory
- withName(String) - Method in class org.apache.druid.query.aggregation.SuppressedAggregatorFactory
- 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
- withNumConnections(int) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.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.
- withOperators(List<OperatorFactory>) - Method in class org.apache.druid.query.operator.WindowOperatorQuery
- 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
QueryRunner
s. - 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 class org.apache.druid.query.operator.WindowOperatorQuery
- 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 interface org.apache.druid.data.input.ByteBufferInputRowParser
- withParseSpec(ParseSpec) - Method in interface org.apache.druid.data.input.impl.InputRowParser
-
Deprecated.
- withParseSpec(ParseSpec) - Method in class org.apache.druid.data.input.impl.MapInputRowParser
- withParseSpec(ParseSpec) - Method in class org.apache.druid.data.input.impl.NoopInputRowParser
- withParseSpec(ParseSpec) - Method in class org.apache.druid.data.input.impl.StringInputRowParser
- 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
- withPostAggregatorSpecs(List<PostAggregator>) - Method in class org.apache.druid.query.topn.TopNQuery
- withPriority(int) - Method in interface org.apache.druid.query.Query
- withProperties(Properties) - Method in class org.apache.druid.guice.StartupInjectorBuilder
- withQuery(Query<U>) - Method in class org.apache.druid.query.QueryPlus
-
Returns a QueryPlus object with
QueryMetrics
from this QueryPlus object, and the providedQuery
. - 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 withQuery
from this QueryPlus and QueryMetrics created using the givenQueryToolChest
, viaQueryToolChest.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 class org.apache.druid.query.operator.WindowOperatorQuery
- 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
- withReadTimeout(Duration) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- 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
- withRowMemoryAndSignatureColumns() - Method in class org.apache.druid.frame.processor.MultiColumnSelectorFactory
-
Create a copy that includes
FrameColumnSelectorFactory.ROW_SIGNATURE_COLUMN
andFrameColumnSelectorFactory.ROW_MEMORY_COLUMN
to potentially enable direct row memory copying. - withScalarArguments(Set<Expr>) - Method in class org.apache.druid.math.expr.Expr.BindingAnalysis
-
Add set of arguments as
Expr.BindingAnalysis.scalarVariables
that are *directly*IdentifierExpr
, else they are ignored. - withSegmentLoader(SegmentizerFactory) - Method in class org.apache.druid.segment.IndexSpec.Builder
- withSelectorPlus(ColumnSelectorPlus) - Method in class org.apache.druid.query.topn.PooledTopNAlgorithm.PooledTopNParams.Builder
- withSerializer(Serializer) - Method in class org.apache.druid.segment.serde.NestedCommonFormatColumnPartSerde.SerializerBuilder
- withShardSpec(ShardSpec) - Method in class org.apache.druid.timeline.DataSegment
- withSize(int) - Method in class org.apache.druid.segment.nested.StructuredDataProcessor.ProcessResults
- withSize(long) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- withSize(long) - Method in class org.apache.druid.timeline.DataSegment
- withSpatialDimensions(List<SpatialDimensionSchema>) - Method in class org.apache.druid.data.input.impl.DimensionsSpec
-
Deprecated.
- 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.
- withSplit(InputSplit) - Method in class org.apache.druid.data.input.impl.CombiningInputSource
- withSplit(InputSplit<URI>) - Method in class org.apache.druid.data.input.impl.HttpInputSource
- withSplit(InputSplit<List<File>>) - Method in class org.apache.druid.data.input.impl.LocalInputSource
- withSplit(InputSplit<T>) - Method in interface org.apache.druid.data.input.impl.SplittableInputSource
-
Helper method for ParallelIndexSupervisorTask.
- withSqlQueryId(String) - Method in class org.apache.druid.query.BaseQuery
- withSqlQueryId(String) - Method in interface org.apache.druid.query.Query
- withSslContext(SSLContext) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- withSslHandshakeTimeout(Duration) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- withStringDictionaryEncoding(StringEncodingStrategy) - Method in class org.apache.druid.segment.IndexSpec.Builder
- 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
- withTasksCreatedPriorTo(Integer, DateTime) - Static method in class org.apache.druid.metadata.TaskLookup.CompleteTaskLookup
- withThreshold(int) - Method in class org.apache.druid.query.topn.TopNQuery
- withTimeout(Query<T>, long) - Static method in class org.apache.druid.query.Queries
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.data.input.impl.CSVParseSpec
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.data.input.impl.DelimitedParseSpec
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.data.input.impl.JavaScriptParseSpec
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.data.input.impl.JSONLowercaseParseSpec
-
Deprecated.
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.data.input.impl.JSONParseSpec
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.data.input.impl.ParseSpec
-
Deprecated.
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.data.input.impl.RegexParseSpec
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.data.input.impl.TimeAndDimsParseSpec
- withTimestampSpec(TimestampSpec) - Method in class org.apache.druid.segment.incremental.IncrementalIndexSchema.Builder
- withTopNMetricVal(Object) - Method in class org.apache.druid.query.topn.DimValHolder.Builder
- withType(ColumnType) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- withTypeName(String) - Method in class org.apache.druid.query.metadata.metadata.ColumnAnalysis.Builder
- withTypeName(String) - Method in class org.apache.druid.segment.serde.ComplexColumnPartSerde.SerializerBuilder
- withUnusedConnectionTimeoutDuration(Duration) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- withUpdatedDataSource(DataSource) - Method in interface org.apache.druid.query.DataSource
-
Returns an updated datasource based on the specified new source.
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.FilteredDataSource
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.FrameBasedInlineDataSource
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.InlineDataSource
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.JoinDataSource
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.LookupDataSource
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.QueryDataSource
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.TableDataSource
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.UnionDataSource
- withUpdatedDataSource(DataSource) - Method in class org.apache.druid.query.UnnestDataSource
- withValue(ColumnarIntsSerializer, boolean, boolean) - Method in class org.apache.druid.segment.serde.DictionaryEncodedColumnPartSerde.SerializerBuilder
- withVersion(String) - Method in class org.apache.druid.timeline.DataSegment
- 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
- withWorkerCount(int) - Method in class org.apache.druid.java.util.http.client.HttpClientConfig.Builder
- WORKER_VERSION - Static variable in class org.apache.druid.query.DruidMetrics
- wrap(byte[]) - Static method in class org.apache.druid.frame.Frame
-
Returns a frame backed by the provided byte array.
- wrap(byte[]) - Static method in class org.apache.druid.frame.key.RowKey
-
Create a key from a byte array.
- wrap(byte[]) - Static method in class org.apache.druid.segment.data.SafeWritableMemory
- 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(Supplier<RetType>) - Method in class org.apache.druid.java.util.common.guava.SequenceWrapper
-
Wraps any bits of the wrapped sequence processing:
Sequence.accumulate(OutType, org.apache.druid.java.util.common.guava.Accumulator<OutType, T>)
orSequence.toYielder(OutType, org.apache.druid.java.util.common.guava.YieldingAccumulator<OutType, T>)
andYielder.next(Object)
on the wrapped yielder. - wrap(Object) - Static method in class org.apache.druid.segment.nested.StructuredData
- wrap(ByteBuffer) - Static method in class org.apache.druid.frame.Frame
-
Returns a frame backed by the provided ByteBuffer.
- wrap(ByteBuffer) - Static method in class org.apache.druid.segment.data.SafeWritableMemory
- wrap(ByteBuffer, int, int) - Static method in class org.apache.druid.segment.data.SafeWritableMemory
- wrap(ByteBuffer, ByteOrder) - Static method in class org.apache.druid.segment.data.SafeWritableMemory
- wrap(Iterator<T>, Closeable) - Static method in class org.apache.druid.java.util.common.CloseableIterators
- wrap(List<OutputChannel>) - Static method in class org.apache.druid.frame.processor.OutputChannels
-
Creates an instance wrapping all the provided channels.
- wrap(Memory) - Static method in class org.apache.druid.frame.Frame
-
Returns a frame backed by the provided Memory.
- wrap(MutableBitmap) - Static method in class org.apache.druid.collections.IntegerSet
- wrap(Sequence<T>, SequenceWrapper) - Static method in class org.apache.druid.java.util.common.guava.Sequences
-
Allows to execute something before, after or around the processing of the given sequence.
- wrap(LookupExtractor) - Static method in class org.apache.druid.segment.join.lookup.LookupJoinable
- wrap(Operator) - Method in class org.apache.druid.query.operator.NaivePartitioningOperatorFactory
- wrap(Operator) - Method in class org.apache.druid.query.operator.NaiveSortOperatorFactory
- wrap(Operator) - Method in interface org.apache.druid.query.operator.OperatorFactory
-
Builds an operator according to the definition of the OperatorFactory and wraps it around the operator passed in to this function.
- wrap(Operator) - Method in class org.apache.druid.query.operator.ScanOperatorFactory
- wrap(Operator) - Method in class org.apache.druid.query.operator.window.WindowOperatorFactory
- wrap(Query<T>) - Static method in class org.apache.druid.query.QueryPlus
-
Returns the minimum bare QueryPlus object with the given query.
- wrap(ColumnSelectorFactory) - Method in class org.apache.druid.segment.VirtualColumns
-
Creates a
VirtualizedColumnSelectorFactory
which can create column selectors forVirtualColumns.virtualColumns
in addition to selectors for all physical columns in the underlying factory. - wrap(Cursor, VirtualColumns, Filter) - Static method in class org.apache.druid.segment.join.PostJoinCursor
- 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 withBitmapFactory.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
- wrapFormatter(DateTimeFormatter) - Static method in class org.apache.druid.java.util.common.DateTimes
-
Creates a
DateTimes.UtcFormatter
that wraps around aDateTimeFormatter
. - wrapIfNeeded(Throwable) - Static method in exception org.apache.druid.query.QueryInterruptedException
- wrapInspector(ColumnInspector) - Method in class org.apache.druid.segment.VirtualColumns
-
Creates a
VirtualizedColumnInspector
that providesColumnCapabilities
information for allVirtualColumns.virtualColumns
in addition to the capabilities of all physical columns in the underlying inspector. - 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(ByteBuffer) - Constructor for class org.apache.druid.collections.bitmap.WrappedBitSetBitmap
- WrappedBitSetBitmap(BitSet) - 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() - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
- WrappedImmutableBitSetBitmap(ByteBuffer) - Constructor for class org.apache.druid.collections.bitmap.WrappedImmutableBitSetBitmap
- WrappedImmutableBitSetBitmap(BitSet) - 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, empty bitmap.
- WrappedSegmentReference - Class in org.apache.druid.segment
-
This class is used as a wrapper for other classes that just want to modify the storage adapter for a datasource.
- WrappedSegmentReference(SegmentReference, Function<StorageAdapter, StorageAdapter>) - Constructor for class org.apache.druid.segment.WrappedSegmentReference
- wrapReadOnly(List<OutputChannel>) - Static method in class org.apache.druid.frame.processor.OutputChannels
-
Creates an instance wrapping read-only versions (see
OutputChannel.readOnly()
) of all the provided channels. - wrapRootGenerationSegment(Segment) - Static method in class org.apache.druid.segment.ReferenceCountingSegment
- wrapSegment(Segment, ShardSpec) - Static method in class org.apache.druid.segment.ReferenceCountingSegment
- wrapSummaryRowIfNeeded(GroupByQuery, Sequence<ResultRow>) - Static method in class org.apache.druid.query.groupby.GroupingEngine
-
Wraps the sequence around if for this query a summary row might be needed in case the input becomes empty.
- writabilityFuture() - Method in class org.apache.druid.frame.channel.ComposingWritableFrameChannel
- writabilityFuture() - Method in interface org.apache.druid.frame.channel.WritableFrameChannel
-
Returns a future that resolves when
WritableFrameChannel.write(org.apache.druid.frame.channel.FrameWithPartition)
is able to receive a new frame without blocking or throwing an exception. - writabilityFuture() - Method in class org.apache.druid.frame.channel.WritableFrameFileChannel
- writable() - Method in class org.apache.druid.frame.channel.BlockingQueueFrameChannel
-
Returns the writable side of this channel.
- writableDuplicate() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- writableDuplicate(ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- WritableFrameChannel - Interface in org.apache.druid.frame.channel
-
Interface for writing a sequence of frames.
- WritableFrameFileChannel - Class in org.apache.druid.frame.channel
-
Frame channel backed by a
FrameFileWriter
. - WritableFrameFileChannel(FrameFileWriter) - Constructor for class org.apache.druid.frame.channel.WritableFrameFileChannel
- writableMemory() - Method in class org.apache.druid.frame.Frame
-
Direct, writable access to this frame's memory.
- writableRegion() - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- writableRegion(long, long, ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableBuffer
- writableRegion(long, long, ByteOrder) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- WritableSupplier<T> - Interface in org.apache.druid.segment.data
- write() - Method in interface org.apache.druid.segment.DictionaryEncodedColumnMerger.ExtendedIndexesMerger
- write() - Method in class org.apache.druid.segment.StringDimensionMergerV9.SpatialIndexesMerger
- write(byte[]) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
- write(byte[]) - Method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
- write(byte[]) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadBuffer
- write(byte[]) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter
- write(byte[]) - Method in class org.apache.druid.segment.serde.cell.CellWriter
- write(byte[]) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
- write(byte[], int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
- write(byte[], int, int) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
- write(int) - Method in class org.apache.druid.query.groupby.epinephelinae.LimitedTemporaryStorage.LimitedOutputStream
- write(int) - Method in class org.apache.druid.segment.data.FixedIndexedIntWriter
- write(int) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
- write(int[]) - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- write(long) - Method in interface org.apache.druid.segment.data.CompressionFactory.LongEncodingWriter
- write(long) - Method in class org.apache.druid.segment.data.DeltaLongEncodingWriter
- 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(String) - Method in class org.apache.druid.segment.data.EncodedStringDictionaryWriter
- write(String) - Method in class org.apache.druid.storage.local.LocalFileStorageConnector
-
Writes the file present with the materialized location as basePath + path.
- write(String) - Method in class org.apache.druid.storage.NilStorageConnector
- write(String) - Method in interface org.apache.druid.storage.StorageConnector
-
Open an
OutputStream
for writing data to the path in the underlying storage system. - write(String, TaskReport.ReportMap) - Method in class org.apache.druid.indexer.report.SingleFileTaskReportFileWriter
- write(String, TaskReport.ReportMap) - Method in interface org.apache.druid.indexer.report.TaskReportFileWriter
- write(ByteBuffer) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- write(ByteBuffer) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadBuffer
- write(ByteBuffer) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter
- write(ByteBuffer) - Method in class org.apache.druid.segment.serde.cell.CellWriter
- write(ByteBuffer) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
- write(ByteBuffer[]) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- write(ByteBuffer[], int, int) - Method in class org.apache.druid.java.util.common.io.smoosh.FileSmoosher.Outer
- write(ByteBuffer, int, T, int) - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- write(ByteBuffer, int, T, int) - Method in interface org.apache.druid.segment.column.TypeStrategy
-
Write a non-null value to the
ByteBuffer
at the requested position. - write(ByteBuffer, Double, int) - Method in class org.apache.druid.segment.column.TypeStrategies.DoubleTypeStrategy
- write(ByteBuffer, Float, int) - Method in class org.apache.druid.segment.column.TypeStrategies.FloatTypeStrategy
- write(ByteBuffer, Long, int) - Method in class org.apache.druid.segment.column.TypeStrategies.LongTypeStrategy
- write(ByteBuffer, Object[], int) - Method in class org.apache.druid.segment.column.TypeStrategies.ArrayTypeStrategy
- write(ByteBuffer, String, int) - Method in class org.apache.druid.segment.column.TypeStrategies.StringTypeStrategy
- write(ByteBuffer, T, int) - Method in class org.apache.druid.segment.column.NullableTypeStrategy
- write(ByteBuffer, T, int) - Method in class org.apache.druid.segment.column.ObjectStrategyComplexTypeStrategy
- write(ByteBuffer, T, int) - Method in interface org.apache.druid.segment.column.TypeStrategy
-
Write a non-null value to the
ByteBuffer
at positionBuffer.position()
. - write(FrameWithPartition) - Method in class org.apache.druid.frame.channel.ComposingWritableFrameChannel
- write(FrameWithPartition) - Method in interface org.apache.druid.frame.channel.WritableFrameChannel
-
Writes a frame with an attached partition number.
- write(FrameWithPartition) - Method in class org.apache.druid.frame.channel.WritableFrameFileChannel
- write(Frame) - Method in interface org.apache.druid.frame.channel.WritableFrameChannel
-
Writes a frame without an attached partition number.
- write(FieldTypeInfo.MutableTypeSet) - Method in class org.apache.druid.segment.nested.FieldTypeInfo.Writer
- write(T) - Method in class org.apache.druid.segment.data.ByteBufferWriter
- write(T) - Method in interface org.apache.druid.segment.data.DictionaryWriter
- write(T) - Method in class org.apache.druid.segment.data.FixedIndexedWriter
- write(T) - Method in class org.apache.druid.segment.data.GenericIndexedWriter
- 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.
- writeAtomically(File, File, FileUtils.OutputStreamConsumer<T>) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Write to a file atomically, by first writing to a temporary file in given tmpDir directory and then moving it to the target location.
- writeAtomically(File, FileUtils.OutputStreamConsumer<T>) - Static method in class org.apache.druid.java.util.common.FileUtils
-
Write to a file atomically, by first writing to a temporary file in the same directory and then moving it to the target location.
- writeBatchEnd(byte[], int) - Method in enum org.apache.druid.java.util.emitter.core.BatchingStrategy
- writeBatchStart(byte[]) - Method in enum org.apache.druid.java.util.emitter.core.BatchingStrategy
- writeBucket(ByteBuffer, int[][], int) - Static method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
-
Write bucket of values to a
ByteBuffer
. - writeBucketV0(ByteBuffer, byte[][], int) - Static method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
-
Write bucket of values to a
ByteBuffer
. - writeBucketV1(ByteBuffer, byte[][], int) - Static method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
-
Write bucket of values to a
ByteBuffer
. - 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
- writeDictionary(Iterable<T>) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- writeDictionaryFile(FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarDoubleColumnSerializer
- writeDictionaryFile(FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarLongColumnSerializer
- writeDictionaryFile(FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- writeDictionaryFile(FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarStringColumnSerializer
- writeFactoryFile(File) - Static method in class org.apache.druid.segment.loading.TombstoneLoadSpec
- writeFloat(OutputStream, float) - Method in class org.apache.druid.common.utils.SerializerUtils
- writeFrame(Frame, int) - Method in class org.apache.druid.frame.file.FrameFileWriter
-
Write a frame.
- writeFrameHeader(WritableMemory, long, FrameType, long, int, int, boolean) - Static method in class org.apache.druid.frame.write.FrameWriterUtils
-
Writes a frame header to a memory locations.
- writeFully(WritableByteChannel, ByteBuffer) - Static method in class org.apache.druid.io.Channels
- writeIndexes(List<IntBuffer>) - Method in class org.apache.druid.segment.AutoTypeColumnMerger
- writeIndexes(List<IntBuffer>) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- 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.NestedDataColumnMergerV4
- writeIndexes(List<IntBuffer>) - Method in class org.apache.druid.segment.NumericDimensionMergerV9
- 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.
- writeInt(ByteBuffer, int) - Static method in class org.apache.druid.segment.data.VByte
-
Write a variable byte (vbyte) encoded integer to a
ByteBuffer
at the current position, advancing the buffer position by the number of bytes required to represent the integer, between 1 and 5 bytes. - writeInt(WritableByteChannel, int) - Static method in class org.apache.druid.common.utils.SerializerUtils
- writeInt(MetaSerdeHelper.IntFieldWriter<T>) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
- writeInternal(FileSmoosher, ByteBuffer, String) - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- writeInternal(FileSmoosher, Serializer, String) - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- writeKeys(WritableMemory, int, int, int, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.DictionaryBuildingSingleValueStringGroupByVectorColumnSelector
- 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.NilGroupByVectorColumnSelector
- 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(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.DictionaryBuildingSingleValueStringGroupByVectorColumnSelector
- writeKeyToResultRow(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.DoubleGroupByVectorColumnSelector
- writeKeyToResultRow(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.FloatGroupByVectorColumnSelector
- writeKeyToResultRow(MemoryPointer, 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(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.LongGroupByVectorColumnSelector
- writeKeyToResultRow(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NilGroupByVectorColumnSelector
- writeKeyToResultRow(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableDoubleGroupByVectorColumnSelector
- writeKeyToResultRow(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableFloatGroupByVectorColumnSelector
- writeKeyToResultRow(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.NullableLongGroupByVectorColumnSelector
- writeKeyToResultRow(MemoryPointer, int, ResultRow, int) - Method in class org.apache.druid.query.groupby.epinephelinae.vector.SingleValueStringGroupByVectorColumnSelector
- writeLong(WritableByteChannel, long) - Method in class org.apache.druid.common.utils.SerializerUtils
- writeLongAndDoubleColumnLength(WritableByteChannel, int, int) - Method in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- writeMergedValueDictionary(List<IndexableAdapter>) - Method in class org.apache.druid.segment.AutoTypeColumnMerger
- writeMergedValueDictionary(List<IndexableAdapter>) - Method in class org.apache.druid.segment.DictionaryEncodedColumnMerger
- 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.NestedDataColumnMergerV4
- writeMergedValueDictionary(List<IndexableAdapter>) - Method in class org.apache.druid.segment.NumericDimensionMergerV9
- writeMessageSeparator(byte[], int) - Method in enum org.apache.druid.java.util.emitter.core.BatchingStrategy
- writeNotNullNullableDouble(ByteBuffer, int, double) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Write a non-null double value to a
ByteBuffer
at the supplied offset. - writeNotNullNullableFloat(ByteBuffer, int, float) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Write a non-null float value to a
ByteBuffer
at the supplied offset. - writeNotNullNullableLong(ByteBuffer, int, long) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Write a non-null long value to a
ByteBuffer
at the supplied offset. - writeNull(ByteBuffer, int) - Static method in class org.apache.druid.segment.column.TypeStrategies
-
Clear and set the 'null' byte of a nullable value to
NullHandling.IS_NULL_BYTE
to aByteBuffer
at the supplied position. - writeNullToMemory(WritableMemory, long) - Method in class org.apache.druid.frame.field.DoubleFieldWriter
- writeNullToMemory(WritableMemory, long) - Method in class org.apache.druid.frame.field.FloatFieldWriter
- writeNullToMemory(WritableMemory, long) - Method in class org.apache.druid.frame.field.LongFieldWriter
- writeNullToMemory(WritableMemory, long) - Method in class org.apache.druid.frame.field.NumericFieldWriter
-
Writes the default value for the type to the memory.
- writeObjectUsingSerializerProvider(JsonGenerator, SerializerProvider, Object) - Static method in class org.apache.druid.java.util.common.jackson.JacksonUtils
-
Serializes an object using a
JsonGenerator
. - 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.firstlast.StringFirstLastUtils
- Writer(SegmentWriteOutMedium) - Constructor for class org.apache.druid.segment.nested.FieldTypeInfo.Writer
- writeReportToStream(ObjectMapper, OutputStream, TaskReport.ReportMap) - Static method in class org.apache.druid.indexer.report.SingleFileTaskReportFileWriter
- writeSelectorToMemory(WritableMemory, long) - Method in class org.apache.druid.frame.field.DoubleFieldWriter
- writeSelectorToMemory(WritableMemory, long) - Method in class org.apache.druid.frame.field.FloatFieldWriter
- writeSelectorToMemory(WritableMemory, long) - Method in class org.apache.druid.frame.field.LongFieldWriter
- writeSelectorToMemory(WritableMemory, long) - Method in class org.apache.druid.frame.field.NumericFieldWriter
-
Writes the value pointed by the selector to memory.
- writeSomething(MetaSerdeHelper.FieldWriter<T>) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
- writeString(WritableByteChannel, String) - Method in class org.apache.druid.common.utils.SerializerUtils
- writeString(T, String) - Method in class org.apache.druid.common.utils.SerializerUtils
- writeTo(int, FileSmoosher) - Method in class org.apache.druid.segment.nested.GlobalDictionaryEncodedFieldColumnWriter
- writeTo(long, long, WritableByteChannel) - Method in class org.apache.druid.segment.data.SafeWritableMemory
- 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(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) - Method in class org.apache.druid.io.ZeroCopyByteArrayOutputStream
- writeTo(WritableByteChannel) - Method in class org.apache.druid.segment.writeout.ByteBufferWriteOutBytes
- 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.
- writeTo(WritableByteChannel, boolean, ByteBuffer, ByteTracker) - Method in class org.apache.druid.frame.Frame
-
Writes this frame to a channel, optionally compressing it as well.
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectBufferStore.TransferredBuffer
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.query.aggregation.AbstractSerializablePairLongObjectColumnSerializer
- 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.CompressedBlockSerializer
- 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.CompressedLongsSerializer
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.CompressedVariableSizedBlobColumnSerializer
- 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.EncodedStringDictionaryWriter
- 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.FixedIndexedIntWriter
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.FixedIndexedWriter
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.GenericIndexedWriter
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.data.IntermediateColumnarLongsSerializer
- 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.nested.FieldTypeInfo.Writer
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializer
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.nested.NestedDataColumnSerializerV4
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.nested.VariantColumnSerializer
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadSerializer
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.serde.cell.BlockCompressedPayloadWriter
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.serde.cell.CellIndexWriter
- writeTo(WritableByteChannel, FileSmoosher) - Method in class org.apache.druid.segment.serde.cell.CellWriter
- 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(WritableByteChannel, FileSmoosher) - Method in interface org.apache.druid.segment.serde.Serializer
-
Writes serialized form of this object to the given channel.
- writeTo(WritableByteChannel, T) - Method in class org.apache.druid.segment.serde.MetaSerdeHelper
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.allocation.AppendableMemory
-
Write current memory to a
WritableMemory
buffer. - writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.ColumnarFrameWriter
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.ComplexFrameColumnWriter
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.ComplexFrameMaker
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.DoubleFrameColumnWriter
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.DoubleFrameMaker
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.FloatFrameColumnWriter
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.FloatFrameMaker
- writeTo(WritableMemory, long) - Method in interface org.apache.druid.frame.write.columnar.FrameColumnWriter
-
Writes the value of the column to the provided memory at the given position
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.LongFrameColumnWriter
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.LongFrameMaker
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.NumericArrayFrameColumnWriter
- writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.columnar.StringFrameColumnWriter
- writeTo(WritableMemory, long) - Method in interface org.apache.druid.frame.write.FrameWriter
-
Writes the frame to the provided memory location, which must have at least
FrameWriter.getTotalSize()
bytes available. - writeTo(WritableMemory, long) - Method in class org.apache.druid.frame.write.RowBasedFrameWriter
- writeTo(WritableMemory, long, long) - Method in class org.apache.druid.frame.field.ComplexFieldWriter
- writeTo(WritableMemory, long, long) - Method in interface org.apache.druid.frame.field.FieldWriter
-
Writes the current selection at the given memory position.
- writeTo(WritableMemory, long, long) - Method in class org.apache.druid.frame.field.NumericArrayFieldWriter
- writeTo(WritableMemory, long, long) - Method in class org.apache.druid.frame.field.NumericFieldWriter
- writeTo(WritableMemory, long, long) - Method in class org.apache.druid.frame.field.StringArrayFieldWriter
- writeTo(WritableMemory, long, long) - Method in class org.apache.druid.frame.field.StringFieldWriter
- writeTo(ImmutableRTree, WriteOutBytes) - Method in class org.apache.druid.segment.data.ImmutableRTreeObjectStrategy
- writeTo(WriteOutBytes) - Method in class org.apache.druid.collections.spatial.ImmutableRTree
- writeTo(T, WriteOutBytes) - Method in interface org.apache.druid.segment.data.ObjectStrategy
- writeToKeyBuffer(int, ColumnValueSelector, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.FixedWidthGroupByColumnSelectorStrategy
- writeToKeyBuffer(int, ColumnValueSelector, ByteBuffer) - Method in interface org.apache.druid.query.groupby.epinephelinae.column.GroupByColumnSelectorStrategy
-
Write a single object from the given selector to the keyBuffer at keyBufferPosition.
- writeToKeyBuffer(int, ColumnValueSelector, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.DictionaryBuilding
- writeToKeyBuffer(int, ColumnValueSelector, ByteBuffer) - Method in class org.apache.druid.query.groupby.epinephelinae.column.KeyMappingMultiValueGroupByColumnSelectorStrategy.PrebuiltDictionary
- writeTranslate(Pair<Integer, PeekingIterator<T>>, int) - Method in class org.apache.druid.segment.DictionaryMergingIterator
- writeV0Header(WritableByteChannel, ByteBuffer) - Method in class org.apache.druid.segment.nested.NestedCommonFormatColumnSerializer
- writeValue(ByteBuffer, byte[]) - Static method in class org.apache.druid.segment.data.FrontCodedIndexedWriter
-
Write a variable length byte[] value to a
ByteBuffer
, storing the length as aVByte
encoded integer followed by the value itself. - writeValue(ByteBuffer, int[]) - Static method in class org.apache.druid.segment.data.FrontCodedIntArrayIndexedWriter
-
Write a variable length int[] value to a
ByteBuffer
, storing the length as aVByte
encoded integer followed by the value itself. - writeValueColumn(FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarDoubleColumnSerializer
- writeValueColumn(FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarLongColumnSerializer
- writeValueColumn(FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarNestedCommonFormatColumnSerializer
-
Called during
ScalarNestedCommonFormatColumnSerializer.writeTo(WritableByteChannel, FileSmoosher)
to allow any type specific value column serializers to use theFileSmoosher
to write stuff to places. - writeValueColumn(FileSmoosher) - Method in class org.apache.druid.segment.nested.ScalarStringColumnSerializer
- WS - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- WS - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
X
- X_DRUID_AUTHOR - Static variable in interface org.apache.druid.audit.AuditManager
- X_DRUID_COMMENT - Static variable in interface org.apache.druid.audit.AuditManager
- xxHash64(long, long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- xxHash64(long, long, long) - Method in class org.apache.druid.segment.data.SafeWritableBase
- XZ - org.apache.druid.utils.CompressionUtils.Format
Y
- YEAR - org.apache.druid.java.util.common.granularity.GranularityType
- YEAR - org.apache.druid.query.expression.TimestampExtractExprMacro.Unit
- YEAR - Static variable in class org.apache.druid.java.util.common.granularity.Granularities
- YES - org.apache.druid.segment.column.RowSignature.Finalization
-
Aggregation results will be finalized.
- yield() - Method in class org.apache.druid.java.util.common.guava.DelegatingYieldingAccumulator
- yield() - Method in class org.apache.druid.java.util.common.guava.FilteringYieldingAccumulator
- yield() - Method in class org.apache.druid.java.util.common.guava.MappingYieldingAccumulator
- yield() - Method in class org.apache.druid.java.util.common.guava.YieldingAccumulator
- yielded() - Method in class org.apache.druid.java.util.common.guava.DelegatingYieldingAccumulator
- yielded() - Method in class org.apache.druid.java.util.common.guava.FilteringYieldingAccumulator
- yielded() - Method in class org.apache.druid.java.util.common.guava.MappingYieldingAccumulator
- yielded() - Method in class org.apache.druid.java.util.common.guava.YieldingAccumulator
- Yielder<T> - Interface in org.apache.druid.java.util.common.guava
-
A Yielder is an object that tries to act like the yield() command/continuations in other languages.
- Yielders - Class in org.apache.druid.java.util.common.guava
- Yielders() - Constructor for class org.apache.druid.java.util.common.guava.Yielders
- YieldingAccumulator<AccumulatedType,InType> - Class in org.apache.druid.java.util.common.guava
-
A YieldingAccumulator is used along with a Yielder in order to replicate continuations in Java.
- YieldingAccumulator() - Constructor for class org.apache.druid.java.util.common.guava.YieldingAccumulator
- YieldingAccumulators - Class in org.apache.druid.java.util.common.guava
- YieldingAccumulators() - Constructor for class org.apache.druid.java.util.common.guava.YieldingAccumulators
- YieldingSequenceBase<T> - Class in org.apache.druid.java.util.common.guava
-
A Sequence that is based entirely on the Yielder implementation.
- YieldingSequenceBase() - Constructor for class org.apache.druid.java.util.common.guava.YieldingSequenceBase
Z
- ZERO - Static variable in class org.apache.druid.java.util.common.HumanReadableBytes
- ZERO_DOUBLE - Static variable in class org.apache.druid.common.config.NullHandling
-
use these values to ensure that
NullHandling.defaultDoubleValue()
,NullHandling.defaultFloatValue()
,NullHandling.defaultFloatValue()
return the same boxed object when returning a constant zero - ZERO_DOUBLE - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
- ZERO_FLOAT - Static variable in class org.apache.druid.common.config.NullHandling
- ZERO_FLOAT - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
- ZERO_LONG - Static variable in class org.apache.druid.common.config.NullHandling
- ZERO_LONG - Static variable in class org.apache.druid.segment.DimensionHandlerUtils
- ZeroCopyByteArrayOutputStream - Class in org.apache.druid.io
- ZeroCopyByteArrayOutputStream() - Constructor for class org.apache.druid.io.ZeroCopyByteArrayOutputStream
- ZeroIndexedInts - Class in org.apache.druid.segment.data
-
An IndexedInts that always returns a row containing a single zero.
- zip(File, File) - Static method in class org.apache.druid.utils.CompressionUtils
-
Zip the contents of directory into the file indicated by outputZipFile.
- zip(File, File, boolean) - Static method in class org.apache.druid.utils.CompressionUtils
-
Zip the contents of directory into the file indicated by outputZipFile.
- zip(File, OutputStream) - Static method in class org.apache.druid.utils.CompressionUtils
-
Zips the contents of the input directory to the output stream.
- ZIP - org.apache.druid.utils.CompressionUtils.Format
- ZIPF - org.apache.druid.segment.generator.GeneratorColumnSchema.ValueDistribution
- zipMapPartial(Iterable<K>, Iterable<V>) - Static method in class org.apache.druid.java.util.common.collect.Utils
-
Create a Map from iterables of keys and values.
- ZSTD - org.apache.druid.segment.data.CompressionStrategy
- ZSTD - org.apache.druid.utils.CompressionUtils.Format
- ZstdCompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.ZstdCompressor
- ZstdDecompressor() - Constructor for class org.apache.druid.segment.data.CompressionStrategy.ZstdDecompressor
- ZTEST - Static variable in class org.apache.druid.query.aggregation.post.PostAggregatorIds
_
- _ATN - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- _ATN - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- _decisionToDFA - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- _decisionToDFA - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- _isNull() - Method in class org.apache.druid.frame.field.NumericFieldReader.Selector
- _serializedATN - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- _serializedATN - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
- _sharedContextCache - Static variable in class org.apache.druid.math.expr.antlr.ExprLexer
- _sharedContextCache - Static variable in class org.apache.druid.math.expr.antlr.ExprParser
All Classes All Packages